You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@ignite.apache.org by GitBox <gi...@apache.org> on 2020/10/01 07:50:17 UTC

[GitHub] [ignite] alex-plekhanov commented on a change in pull request #8293: PAGE_LISTS and PARTITION_STATES views documentation

alex-plekhanov commented on a change in pull request #8293:
URL: https://github.com/apache/ignite/pull/8293#discussion_r498049133



##########
File path: docs/_docs/monitoring-metrics/system-views.adoc
##########
@@ -601,76 +601,42 @@ Page lists organized in buckets. Each bucket group pages with about the same siz
 If persistence is enabled page lists are created for each partition of each cache group, to view such page lists cacheGroupPageLists system view (SQL name CACHE_GROUP_PAGE_LISTS) can be used. If persistence is disabled page lists are created for each data region, in this case, dataRegionPageLists system view (SQL name DATA_REGION_PAGE_LISTS) can be used. These views contain information about each bucket of each page list what is useful to understand how much data can be inserted into the cache without allocating new pages and also helps to detect skews in page lists utilization.
 
 
-////
-=== Columns of cacheGroupPageLists
-
-
-|NAME  |  SQL NAME   | TYPE |   DESCRIPTION
-|cacheGroupId | CACHE_GROUP_ID |  int| Cache group ID
-|partitionId | PARTITION_ID |    int| Partition ID
-|name | NAME |    String|  Page list name
-|bucketNumber | BUCKET_NUMBER |   int| Bucket number
-|bucketSize | BUCKET_SIZE | long  |  Count of pages in the bucket
-|stripesCount | STRIPES_COUNT |   int| Count of stripes used by this bucket. Stripes are used to avoid contention.
-|cachedPagesCount | CACHED_PAGES_COUNT |  int| Count of pages in onheap page list cache for this bucket
-|CACHE_TYPE | string ||  Cache type
-|CACHE_MODE | string ||  Cache mode
-|ATOMICITY_MODE | string |  Atomicity mode
-|CACHE_GROUP_NAME | string |  Cache group name
-|AFFINITY | string |  toString representation of affinity function
-|AFFINITY_MAPPER | string |  toString representation of affinity mapper
-|BACKUPS | int | backup count
-|CACHE_GROUP_ID | int | cache group id
-|CACHE_LOADER_FACTORY | string |  toString representation of cache loader factory
-|CACHE_STORE_FACTORY | string |  toString representation of cache store factory
-|CACHE_WRITER_FACTORY | string |  toString representation of cache writer factory
-|DATA_REGION_NAME | string |  Data region name
-|DEFAULT_LOCK_TIMEOUT | long |    Lock timeout in milliseconds
-|EVICTION_FILTER | string |  toString representation of eviction filter
-|EVICTION_POLICY_FACTORY | string |  toString representation of eviction policy factory
-|EXPIRY_POLICY_FACTORY | string |  toString representation of expiry policy factory
-|INTERCEPTOR | string |  toString representation of interceptor
-|IS_COPY_ON_READ | boolean | Flag indicating whether a copy of the value stored in the on-heap cache
-|IS_EAGER_TTL | boolean | Flag indicating whether expired cache entries will be eagerly removed from cache
-|IS_ENCRYPTION_ENABLED | boolean | True if cache data encrypted
-|IS_EVENTS_DISABLED | boolean | True if events disabled for this cache
-|IS_INVALIDATE | boolean | True if values will be invalidated (nullified) upon commit in near cache
-|IS_LOAD_PREVIOUS_VALUE | boolean | True if value should be loaded from store if it is not in the cache
-|IS_MANAGEMENT_ENABLED | boolean |
-|IS_NEAR_CACHE_ENABLED | boolean | True if near cache enabled
-|IS_ONHEAP_CACHE_ENABLED | boolean | True if on heap cache enabled
-|IS_READ_FROM_BACKUP | boolean | True if read operation should be performed from backup node
-|IS_READ_THROUGH | boolean | True if read from third party storage enabled
-|IS_SQL_ESCAPE_ALL | boolean | If true all the SQL table and field names will be escaped with double quotes
-|IS_SQL_ONHEAP_CACHE_ENABLED | boolean | If true SQL on-heap cache is enabled. When enabled, Ignite will cache SQL rows as they are accessed by query engine. Rows are invalidated and evicted from cache when relevant cache entry is either changed or evicted.
-|IS_STATISTICS_ENABLED | boolean |
-|IS_STORE_KEEP_BINARY | boolean | Flag indicating that {@link CacheStore} implementation is working with binary objects instead of Java objects.
-|IS_WRITE_BEHIND_ENABLED | boolean | Flag indicating whether Ignite should use write-behind behaviour for the cache store
-|IS_WRITE_THROUGH | boolean | True if write to third party storage enabled
-|MAX_CONCURRENT_ASYNC_OPERATIONS | int | Maximum number of allowed concurrent asynchronous operations. If 0 returned then number of concurrent asynchronous operations is unlimited
-|MAX_QUERY_ITERATORS_COUNT | int | Maximum number of query iterators that can be stored. Iterators are stored to support query pagination when each page of data is sent to user's node only on demand
-|NEAR_CACHE_EVICTION_POLICY_FACTORY | string |  toString representation of near cache eviction policy factory
-|NEAR_CACHE_START_SIZE | int | Initial cache size for near cache which will be used to pre-create internal hash table after start.
-|NODE_FILTER | string |  toString representation of node filter
-|PARTITION_LOSS_POLICY | string |  toString representation of partition loss policy
-|QUERY_DETAIL_METRICS_SIZE | int | size of queries detail metrics that will be stored in memory for monitoring purposes. If 0 then history will not be collected.
-|QUERY_PARALLELISM | int | Hint to query execution engine on desired degree of parallelism within a single node
-|REBALANCE_BATCH_SIZE | int | Size (in bytes) to be loaded within a single rebalance message
-|REBALANCE_BATCHES_PREFETCH_COUNT | int | Number of batches generated by supply node at rebalancing start
-|REBALANCE_DELAY | long |    Rebalance delay in milliseconds
-|REBALANCE_MODE | string |  Rebalance mode
-|REBALANCE_ORDER | int | Rebalance order
-|REBALANCE_THROTTLE | long |    Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network
-|REBALANCE_TIMEOUT | long |    Rebalance timeout in milliseconds
-|SQL_INDEX_MAX_INLINE_SIZE | int | Index inline size in bytes
-|SQL_ONHEAP_CACHE_MAX_SIZE | int | Maximum SQL on-heap cache. Measured in number of rows. When maximum size is reached oldest cached rows will be evicted.
-|SQL_SCHEMA | string |  Schema name
-|TOPOLOGY_VALIDATOR | string |  toString representation of topology validator
-|WRITE_BEHIND_BATCH_SIZE | int | Maximum batch size for write-behind cache store operations
-|WRITE_BEHIND_COALESCING | boolean | Write coalescing flag for write-behind cache store operations. Store operations (get or remove) with the same key are combined or coalesced to single, resulting operation to reduce pressure to underlying cache store
-|WRITE_BEHIND_FLUSH_FREQUENCY | long |    Frequency with which write-behind cache is flushed to the cache store in milliseconds
-|WRITE_BEHIND_FLUSH_SIZE | int | Maximum size of the write-behind cache. If cache size exceeds this value, all cached items are flushed to the cache store and write cache is cleared
-|WRITE_BEHIND_FLUSH_THREAD_COUNT | int | Number of threads that will perform cache flushing
-|WRITE_SYNCHRONIZATION_MODE | string |  Gets write synchronization mode
+=== CACHE_GROUP_PAGE_LISTS
+
+[{table_opts}]
+|===
+|Column | Data type |  Description
+|CACHE_GROUP_ID |  int| Cache group ID
+|PARTITION_ID |    int| Partition ID
+|NAME |    string|  Page list name
+|BUCKET_NUMBER |   int| Bucket number
+|BUCKET_SIZE | long  |  Count of pages in the bucket
+|STRIPES_COUNT |   int| Count of stripes used by this bucket. Stripes are used to avoid contention.
+|CACHED_PAGES_COUNT |  int| Count of pages in onheap page list cache for this bucket
+|===
+
+=== DATA_REGION_PAGE_LISTS
+
+[{table_opts}]
+|===
+|Column | Data type |  Description
+|NAME |    string|  Page list name
+|BUCKET_NUMBER |   int| Bucket number
+|BUCKET_SIZE | long  |  Count of pages in the bucket
+|STRIPES_COUNT |   int| Count of stripes used by this bucket. Stripes are used to avoid contention.
+|CACHED_PAGES_COUNT |  int| Count of pages in onheap page list cache for this bucket
+|===
+
+== PARTITION_STATES
 
-////
+This view exposes information about distribution of cache group partitions across cluster nodes.
+
+[{table_opts}]
+|===
+|Column | Data type |  Description
+|CACHE_GROUP_ID |  int| Cache group ID
+|PARTITION_ID |    int| Partition ID
+|NODE_ID | UUID | Node ID
+|STATE | string | Partition state
+|IS_PRIMARY | boolean  | Primary partition flag

Review comment:
       Done




----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org