You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by db...@apache.org on 2017/08/14 22:23:31 UTC

[3/5] geode git commit: GEODE-3395 Variable-ize product version and name in user guide - Reference section

http://git-wip-us.apache.org/repos/asf/geode/blob/13ad4b6e/geode-docs/reference/statistics_list.html.md.erb
----------------------------------------------------------------------
diff --git a/geode-docs/reference/statistics_list.html.md.erb b/geode-docs/reference/statistics_list.html.md.erb
new file mode 100644
index 0000000..f26075d
--- /dev/null
+++ b/geode-docs/reference/statistics_list.html.md.erb
@@ -0,0 +1,1310 @@
+---
+title: Geode Statistics List
+---
+
+<!--
+Licensed to the Apache Software Foundation (ASF) under one or more
+contributor license agreements.  See the NOTICE file distributed with
+this work for additional information regarding copyright ownership.
+The ASF licenses this file to You under the Apache License, Version 2.0
+(the "License"); you may not use this file except in compliance with
+the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
+-->
+
+<a id="statistics_list"></a>
+
+
+This section describes the primary statistics gathered by Geode when statistics are enabled.
+
+All statistics gathering requires the `gemfire.properties` `statistic-sampling-enabled` in `gemfire.properties` file to be true. Statistics that use time require the `gemfire.properties` `enable-time-statistics` to be true.
+
+Performance statistics are collected for each Java application or cache server that connects to a distributed system.
+
+-   **[Cache Performance (CachePerfStats)](#section_DEF8D3644D3246AB8F06FE09A37DC5C8)**
+
+-   **[Cache Server (CacheServerStats)](#section_EF5C2C59BFC74FFB8607F9571AB9A471)**
+
+-   **[Client-Side Notifications (CacheClientUpdaterStats)](#section_B08C0783BBF9489E8BB48B4AEC597C62)**
+
+-   **[Client-to-Server Messaging Performance (ClientStats)](#section_04B7D7387E584712B7710B5ED1E876BB)**
+
+-   **[Client Connection Pool (PoolStats)](#section_6C247F61DB834C079A16BE92789D4692)**
+
+-   **[Continuous Querying (CQStatistics)](#section_66C0E7748501480B85209D57D24256D5)**
+
+-   **[Delta Propagation (DeltaPropagationStatistics)](#section_D4ABED3FF94245C0BEE0F6FC9481E867)**
+
+-   **[Disk Space Usage (DiskDirStatistics)](#section_6C2BECC63A83456190B029DEDB8F4BE3)**
+
+-   **[Disk Usage and Performance (DiskRegionStatistics)](#section_983BFC6D53C74829A04A91C39E06315F)**
+
+-   **[Distributed System Messaging (DistributionStats)](#section_ACB4161F10D64BC0B15871D003FF6FDF)**
+
+-   **[Distributed Lock Services (DLockStats)](#section_78D346A580724E1EA645E31626EECE40)**
+
+-   **[Function Execution (FunctionServiceStatistics)](#section_5E211DDB0E8640689AD0A4659511E17A)**
+
+-   **[Gateway Queue (GatewayStatistics)](#section_C4199A541B1F4B82B6178C416C0FAE4B)**
+
+-   **[Indexes (IndexStats)](#section_86A61860024B480592DAC67FFB882538)**
+
+-   **[JVM Performance](#section_607C3867602E410CAE5FAB26A7FF1CB9)**
+
+-   **[Locator (LocatorStatistics)](#section_C48B654F973E4B44AD825D459C23A6CD)**
+
+-   **[Lucene Indexes (LuceneIndexStats)](#LuceneStats)**
+
+-   **[Off-Heap (OffHeapMemoryStats)](#topic_ohc_tjk_w5)**
+
+-   **[Operating System Statistics - Linux](#section_923B28F01BC3416786D3AFBD87F22A5E)**
+
+-   **[Partitioned Regions (PartitionedRegion&lt;partitioned\_region\_name&gt;Statistics)](#section_35AC170770C944C3A336D9AEC2D2F7C5)**
+
+-   **[Region Entry Eviction – Count-Based (LRUStatistics)](#section_374FBD92A3B74F6FA08AA23047929B4F)**
+
+-   **[Region Entry Eviction – Size-based (LRUStatistics)](#section_3D2AA2BCE5B6485699A7B6ADD1C49FF7)**
+
+-   **[Server Notifications for All Clients (CacheClientNotifierStatistics)](#section_5362EF9AECBC48D69475697109ABEDFA)**
+
+-   **[Server Notifications for Single Client (CacheClientProxyStatistics)](#section_E03865F509E543D9B8F9462B3DA6255E)**
+
+-   **[Server-to-Client Messaging Performance (ClientSubscriptionStats)](#section_3AB1C0AA55014163A2BBF68E13D25E3A)**
+
+-   **[Statistics Collection (StatSampler)](#section_55F3AF6413474317902845EE4996CC21)**
+
+## <a id="section_DEF8D3644D3246AB8F06FE09A37DC5C8" class="no-quick-link"></a>Cache Performance (CachePerfStats)
+
+Statistics for the Geode cache. These can be used to determine the type and number of cache operations being performed and how much time they consume.
+
+Regarding Geode cache transactions, transaction-related statistics are compiled and stored as properties in the CachePerfStats statistic resource. Because the transaction’s data scope is the cache, these statistics are collected on a per-cache basis.
+
+The primary statistics are:
+
+| Statistic                        | Description                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                              |
+|----------------------------------|--------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------|
+| `cacheListenerCallsCompleted`    | Total number of times a cache listener call has completed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `cacheListenerCallsInProgress`   | Current number of threads doing a cache listener call.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+| `cacheListenerCallTime`          | Total time spent doing cache listener calls.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                             |
+| `cacheWriterCallsCompleted`      | Total number of times a cache writer call has completed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                 |
+| `cacheWriterCallsInProgress`     | Current number of threads doing a cache writer call.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `cacheWriterCallTime`            | Total time spent doing cache writer calls.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `compressions`                   | Total number of compression operations.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                  |
+| `compressTime`                   | Total time, in nanoseconds, spent compressing data.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `conflatedEvents`                | The number of events that were conflated, and not delivered to event listeners or gateway senders on this member. Events are typically conflated because a later event was already applied to the cache, or because a concurrent event was ignored to ensure cache consistency. Note that some members may discard an update while other members apply the update, depending on the order in which each member receives the update. For this reason, the `conflatedEvents` statistic will differ for each Geode member. See [Consistency for Region Updates](../developing/distributed_regions/region_entry_versions.html#topic_CF2798D3E12647F182C2CEC4A46E2045). |
+| `creates`                        | The total number of times an entry is added to this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `decompressions`                 | Total number of decompression operations.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                |
+| `decompressTime`                 | Total time, in nanoseconds, spent decompressing data.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                    |
+| `destroys`                       | The total number of times a cache object entry has been destroyed in this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                         |
+| `eventQueueSize`                 | The number of cache events waiting to be processed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `eventQueueThrottleCount`        | The total number of times a thread was delayed in adding an event to the event queue.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                    |
+| `eventQueueThrottleTime`         | The total amount of time, in nanoseconds, spent delayed by the event queue throttle.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `eventThreads`                   | The number of threads currently processing events.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                       |
+| `getInitialImageKeysReceived`    | Total number of keys received while doing getInitialImage operations.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                    |
+| `getInitialImagesCompleted`      | Total number of times getInitialImages initiated by this cache have completed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                           |
+| `getInitialImagesInProgressDesc` | Current number of getInitialImage operations currently in progress.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `getInitialImageTime`            | Total time spent doing getInitialImages for region creation.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                             |
+| `getsDesc`                       | The total number of times a successful get has been done on this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                  |
+| `getTime`                        | Total time spent doing get operations from this cache (including netsearch and netload).                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                 |
+| `invalidates`                    | The total number of times an existing cache object entry value in this cache has been invalidated.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                       |
+| `loadsCompleted`                 | Total number of times a load on this cache has completed as a result of either a local get() or a remote netload.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                        |
+| `loadsInProgress`                | Current number of threads in this cache doing a cache load.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                              |
+| `loadTime`                       | Total time spent invoking loaders on this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                         |
+| `misses`                         | Total number of times a get on the cache did not find a value already in local memory. The number of hits (that is, gets that did not miss) can be calculated by subtracting misses from gets.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                           |
+| `netloadsCompleted`              | Total number of times a network load initiated on this cache has completed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                              |
+| `netloadsInProgress`             | Current number of threads doing a network load initiated by a get() in this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                       |
+| `netloadTime`                    | Total time spent doing network loads on this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `netsearchesCompleted`           | Total number of times network searches initiated by this cache have completed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                           |
+| `netsearchesInProgress`          | Current number of threads doing a network search initiated by a get() in this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `netsearchTimeDesc`              | Total time spent doing network searches for cache values.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                |
+| `nonReplicatedTombstonesSize`    | The approximate number of bytes that are currently consumed by tombstones in non-replicated regions. See [Consistency for Region Updates](../developing/distributed_regions/region_entry_versions.html#topic_CF2798D3E12647F182C2CEC4A46E2045).                                                                                                                                                                                                                                                                                                                                                                                                                                                 |
+| `partitionedRegions`             | The current number of partitioned regions in the cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                  |
+| `postCompressedBytes`            | Total number of bytes after compressing.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                 |
+| `preCompressedBytes`             | Total number of bytes before compressing.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                |
+| `putAlls`                        | The total number of times a map is added or replaced in this cache as a result of a local operation. Note, this only counts putAlls done explicitly on this cache; it does not count updates pushed from other caches.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+| `putallTime`                     | Total time spent replacing a map in this cache as a result of a local operation. This includes synchronizing on the map, invoking cache callbacks, sending messages to other caches and waiting for responses (if required).                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                             |
+| `puts`                           | The total number of times an entry is added or replaced in this cache as a result of a local operation (put(), create(), or get() which results in load, netsearch, or netloading a value). Note, this only counts puts done explicitly on this cache; it does not count updates pushed from other caches.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `putTime`                        | Total time spent adding or replacing an entry in this cache as a result of a local operation. This includes synchronizing on the map, invoking cache callbacks, sending messages to other caches, and waiting for responses (if required).                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `queryExecutions`                | Total number of times some query has been executed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `queryExecutionTime`             | Total time spent executing queries.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `regions`                        | The current number of regions in the cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                              |
+| `replicatedTombstonesSize`       | The approximate number of bytes that are currently consumed by tombstones in replicated or partitioned regions. See [Consistency for Region Updates](../developing/distributed_regions/region_entry_versions.html#topic_CF2798D3E12647F182C2CEC4A46E2045).                                                                                                                                                                                                                                                                                                                                                                                                                                      |
+| `tombstoneCount`                 | The total number of tombstone entries created for performing concurrency checks. See [Consistency for Region Updates](../developing/distributed_regions/region_entry_versions.html#topic_CF2798D3E12647F182C2CEC4A46E2045).                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `tombstoneGCCount`               | The total number of tombstone garbage collection cycles that a member has performed. See [Consistency for Region Updates](../developing/distributed_regions/region_entry_versions.html#topic_CF2798D3E12647F182C2CEC4A46E2045).                                                                                                                                                                                                                                                                                                                                                                                                                                                                 |
+| `txCommitChanges`                | Total number of changes made by committed transactions.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                  |
+| `txCommits`                      | Total number of times a transaction commit has succeeded.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                |
+| `txCommitTime`                   | The total amount of time, in nanoseconds, spent doing successful transaction commits.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                    |
+| `txConflictCheckTime`            | The total amount of time, in nanoseconds, spent doing conflict checks during transaction commit.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                         |
+| `txFailedLifeTime`               | The total amount of time, in nanoseconds, spent in a transaction before a failed commit. The time measured starts at transaction begin and ends when commit is called.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+| `txFailureChanges`               | Total number of changes lost by failed transactions.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `txFailures`                     | Total number of times a transaction commit has failed.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+| `txFailureTime`                  | The total amount of time, in nanoseconds, spent doing failed transaction commits.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                        |
+| `txRollbackChanges`              | Total number of changes lost by explicit transaction rollbacks.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                          |
+| `txRollbackLifeTime`             | The total amount of time, in nanoseconds, spent in a transaction before an explicit rollback. The time measured starts at transaction begin and ends when rollback is called.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                            |
+| `txRollbacks`                    | Total number of times a transaction has been explicitly rolled back.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                     |
+| `txRollbackTime`                 | The total amount of time, in nanoseconds, spent doing explicit transaction rollbacks.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                    |
+| `txSuccessLifeTime`              | The total amount of time, in nanoseconds, spent in a transaction before a successful commit. The time measured starts at transaction begin and ends when commit is called.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                               |
+| `updates`                        | The total number of updates originating remotely that have been applied to this cache.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+| `updateTime`                     | Total time spent performing an update.                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                   |
+
+## <a id="section_EF5C2C59BFC74FFB8607F9571AB9A471" class="no-quick-link"></a>Cache Server (CacheServerStats)
+
+Statistics used for cache servers and for gateway receivers are recorded in CacheServerStats in a cache server. The primary statistics are:
+
+| Statistic                                 | Description                                                                                                                                    |
+|-------------------------------------------|------------------------------------------------------------------------------------------------------------------------------------------------|
+| `abandonedReadRequests`                   | Number of read operations (requests) abandoned by clients.                                                                                     |
+| `abandonedWriteRequests`                  | Number of write operations (requests) abandoned by clients.                                                                                    |
+| `acceptsInProgress`                       | Current number of server accepts that are attempting to do the initial handshake with the client.                                              |
+| `acceptThreadStarts`                      | Total number of threads created (starts) to deal with an accepted socket. Note, this is not the current number of threads.                     |
+| `batchSize`                               | The size (in bytes) of the batches received.                                                                                                   |
+| `clearRegionRequests`                     | Number of cache client operations clearRegion requests.                                                                                        |
+| `clearRegionResponses`                    | Number of clearRegion responses written to the cache client.                                                                                   |
+| `clientNotificationRequests`              | Number of cache client operations notification requests.                                                                                       |
+| `clientReadyRequests`                     | Number of cache client ready requests.                                                                                                         |
+| `clientReadyResponses`                    | Number of client ready responses written to the cache client.                                                                                  |
+| `closeConnectionRequests`                 | Number of cache client close connection operations requests.                                                                                   |
+| `connectionLoad`                          | The load from client to server connections as reported by the load probe installed in this server.                                             |
+| `connectionsTimedOut`                     | Total number of connections that have been timed out by the server because of client inactivity.                                               |
+| `connectionThreads`                       | Current number of threads dealing with a client connection.                                                                                    |
+| `connectionThreadStarts`                  | Total number of threads created (starts) to deal with a client connection. Note, this is not the current number of threads.                    |
+| `containsKeyRequests`                     | Number of cache client operations containsKey requests.                                                                                        |
+| `containsKeyResponses`                    | Number of containsKey responses written to the cache client.                                                                                   |
+| `currentClientConnections`                | Number of sockets accepted.                                                                                                                    |
+| `currentClients`                          | Number of client virtual machines (clients) connected.                                                                                         |
+| `destroyRegionRequests`                   | Number of cache client operations destroyRegion requests.                                                                                      |
+| `destroyRegionResponses`                  | Number of destroyRegion responses written to the cache client.                                                                                 |
+| `destroyRequests`                         | Number of cache client operations destroy requests.                                                                                            |
+| `destroyResponses`                        | Number of destroy responses written to the cache client.                                                                                       |
+| `failedConnectionAttempts`                | Number of failed connection attempts.                                                                                                          |
+| `getRequests`                             | Number of cache client operations get requests.                                                                                                |
+| `getResponses`                            | Number of getResponses written to the cache client.                                                                                            |
+| `loadPerConnection`                       | The estimate of how much load i.s added for each new connection as reported by the load probe installed in this server.                        |
+| `loadPerQueue`                            | The estimate of how much load would be added for each new subscription connection as reported by the load probe installed in this server.      |
+| `messageBytesBeingReceived`               | Current number of bytes consumed by messages being received or processed.                                                                      |
+| `messagesBeingReceived`                   | Current number of messages being received off the network or being processed after reception.                                                  |
+| `outOfOrderGatewayBatchIds`               | Number of Out of Order batch IDs (batches).                                                                                                    |
+| `processBatchRequests`                    | Number of cache client operations processBatch requests.                                                                                       |
+| `processBatchResponses`                   | Number of processBatch responses written to the cache client.                                                                                  |
+| `processBatchTime`                        | Total time, in nanoseconds, spent in processing a cache client processBatch request.                                                           |
+| `processClearRegionTime`                  | Total time, in nanoseconds, spent in processing a cache client clearRegion request, including the time to clear the region from the cache.     |
+| `processClientNotificationTime`           | Total time, in nanoseconds, spent in processing a cache client notification request.                                                           |
+| `processClientReadyTime`                  | Total time, in nanoseconds, spent in processing a cache client ready request, including the time to destroy an object from the cache.          |
+| `processCloseConnectionTime`              | Total time, in nanoseconds, spent in processing a cache client close connection request.                                                       |
+| `processContainsKeyTime`                  | Total time spent, in nanoseconds, processing a containsKey request.                                                                            |
+| `processDestroyRegionTime`                | Total time, in nanoseconds, spent in processing a cache client destroyRegion request, including the time to destroy the region from the cache. |
+| `processDestroyTime`                      | Total time, in nanoseconds, spent in processing a cache client destroy request, including the time to destroy an object from the cache.        |
+| `processGetTime`                          | Total time, in nanoseconds, spent in processing a cache client get request, including the time to get an object from the cache.                |
+| `processPutAllTime`                       | Total time, in nanoseconds, spent in processing a cache client putAll request, including the time to put all objects into the cache.           |
+| `processPutTime`                          | Total time, in nanoseconds, spent in processing a cache client put request, including the time to put an object into the cache.                |
+| `processQueryTime`                        | Total time, in nanoseconds, spent in processing a cache client query request, including the time to destroy an object from the cache.          |
+| `processUpdateClientNotificationTime`     | Total time, in nanoseconds, spent in processing a client notification update request.                                                          |
+| `putAllRequests`                          | Number of cache client operations putAll requests.                                                                                             |
+| `putAllResponses`                         | Number of putAllResponses written to the cache client.                                                                                         |
+| `putRequests`                             | Number of cache client operations put requests.                                                                                                |
+| `putResponses`                            | Number of putResponses written to the cache client.                                                                                            |
+| `queryRequests`                           | Number of cache client operations query requests.                                                                                              |
+| `queryResponses`                          | Number of query responses written to the cache client.                                                                                         |
+| `queueLoad`                               | The load from subscription queues as reported by the load probe installed in this server                                                       |
+| `readClearRegionRequestTime`              | Total time, in nanoseconds, spent in reading clearRegion requests.                                                                             |
+| `readClientNotificationRequestTime`       | Total time, in nanoseconds, spent in reading client notification requests.                                                                     |
+| `readClientReadyRequestTime`              | Total time, in nanoseconds, spent in reading cache client ready requests.                                                                      |
+| `readCloseConnectionRequestTime`          | Total time, in nanoseconds, spent in reading close connection requests.                                                                        |
+| `readContainsKeyRequestTime`              | Total time, in nanoseconds, spent reading containsKey requests.                                                                                |
+| `readDestroyRegionRequestTime`            | Total time, in nanoseconds, spent in reading destroyRegion requests.                                                                           |
+| `readDestroyRequestTime`                  | Total time, in nanoseconds, spent in reading destroy requests.                                                                                 |
+| `readGetRequestTime`                      | Total time, in nanoseconds, spent in reading get requests.                                                                                     |
+| `readProcessBatchRequestTime`             | Total time, in nanoseconds, spent in reading processBatch requests.                                                                            |
+| `readPutAllRequestTime`                   | Total time, in nanoseconds, spent in reading putAll requests.                                                                                  |
+| `readPutRequestTime`                      | Total time, in nanoseconds, spent in reading put requests.                                                                                     |
+| `readQueryRequestTime`                    | Total time, in nanoseconds, spent in reading query requests.                                                                                   |
+| `readUpdateClientNotificationRequestTime` | Total time, in nanoseconds, spent in reading client notification update requests.                                                              |
+| `receivedBytes`                           | Total number of bytes received from clients.                                                                                                   |
+| `sentBytes`                               | Total number of bytes sent to clients.                                                                                                         |
+| `threadQueueSize`                         | Current number of connections waiting for a thread to start processing their message.                                                          |
+| `updateClientNotificationRequests`        | Number of cache client notification update requests.                                                                                           |
+| `writeClearRegionResponseTime`            | Total time, in nanoseconds, spent in writing clearRegion responses.                                                                            |
+| `writeClientReadyResponseTime`            | Total time, in nanoseconds, spent in writing client ready responses.                                                                           |
+| `writeContainsKeyResponseTime`            | Total time, in nanoseconds, spent writing containsKey responses.                                                                               |
+| `writeDestroyRegionResponseTime`          | Total time, in nanoseconds, spent in writing destroyRegion responses.                                                                          |
+| `writeDestroyResponseTime`                | Total time, in nanoseconds, spent in writing destroy responses.                                                                                |
+| `writeGetResponseTime`                    | Total time, in nanoseconds, spent in writing get responses.                                                                                    |
+| `writeProcessBatchResponseTime`           | Total time, in nanoseconds, spent in writing processBatch responses.                                                                           |
+| `writePutAllResponseTime`                 | Total time, in nanoseconds, spent in writing putAll responses.                                                                                 |
+| `writePutResponseTime`                    | Total time, in nanoseconds, spent in writing put responses.                                                                                    |
+| `writeQueryResponseTime`                  | Total time, in nanoseconds, spent in writing query responses.                                                                                  |
+
+## <a id="section_B08C0783BBF9489E8BB48B4AEC597C62" class="no-quick-link"></a>Client-Side Notifications (CacheClientUpdaterStats)
+
+Statistics in a client that pertain to server-to-client data pushed from the server over a queue to the client (they are the client side of the server’s `CacheClientNotifierStatistics`) :
+
+| Statistic                   | Description                                                                                  |
+|-----------------------------|----------------------------------------------------------------------------------------------|
+| `receivedBytes`             | Total number of bytes received from the server.                                              |
+| `messagesBeingReceived`     | Current number of message being received off the network or being processed after reception. |
+| `messageBytesBeingReceived` | Current number of bytes consumed by messages being received or processed.                    |
+
+## <a id="section_04B7D7387E584712B7710B5ED1E876BB" class="no-quick-link"></a>Client-to-Server Messaging Performance (ClientStats)
+
+These statistics are in a client and they describe all the messages sent from the client to a specific server. The primary statistics are:
+
+| Statistic                              | Description                                                                                   |
+|----------------------------------------|-----------------------------------------------------------------------------------------------|
+| `clearFailures`                        | Total number of clear attempts that have failed.                                              |
+| `clears`                               | Total number of clears completed successfully.                                                |
+| `clearSendFailures`                    | Total number of clearSends that have failed.                                                  |
+| `clearSends`                           | Total number of clearSends that have completed successfully.                                  |
+| `clearSendsInProgress`                 | Current number of clearSends being executed.                                                  |
+| `clearSendTime`                        | Total amount of time, in nanoseconds, spent doing clearSends.                                 |
+| `clearsInProgress`                     | Current number of clears being executed.                                                      |
+| `clearTime`                            | Total amount of time, in nanoseconds, spent doing clears.                                     |
+| `clearTimeouts`                        | Total number of clear attempts that have timed out.                                           |
+| `closeConFailures`                     | Total number of closeCon attempts that have failed.                                           |
+| `closeCons`                            | Total number of closeCons that have completed successfully.                                   |
+| `closeConSendFailures`                 | Total number of closeConSends that have failed.                                               |
+| `closeConSends`                        | Total number of closeConSends that have completed successfully.                               |
+| `closeConSendsInProgress`              | Current number of closeConSends being executed.                                               |
+| `closeConSendTime`                     | Total amount of time, in nanoseconds, spent doing closeConSends.                              |
+| `closeConsInProgress`                  | Current number of closeCons being executed.                                                   |
+| `closeConTime`                         | Total amount of time, in nanoseconds, spent doing closeCons.                                  |
+| `closeConTimeouts`                     | Total number of closeCon attempts that have timed out.                                        |
+| `connections`                          | Current number of connections.                                                                |
+| `connects`                             | Total number of times a connection has been created.                                          |
+| `containsKeyFailures`                  | Total number of containsKey attempts that have failed.                                        |
+| `containsKeys`                         | Total number of containsKeys that completed successfully.                                     |
+| `containsKeySendFailures`              | Total number of containsKeySends that have failed.                                            |
+| `containsKeySends`                     | Total number of containsKeySends that have completed successfully.                            |
+| `containsKeySendsInProgress`           | Current number of containsKeySends being executed.                                            |
+| `containsKeySendTime`                  | Total amount of time, in nanoseconds, spent doing containsKeyends.                            |
+| `containsKeysInProgress`               | Current number of containsKeys being executed.                                                |
+| `containsKeyTime`                      | Total amount of time, in nanoseconds, spent doing containsKeys.                               |
+| `containsKeyTimeouts`                  | Total number of containsKey attempts that have timed out.                                     |
+| `destroyFailures`                      | Total number of destroy attempts that have failed.                                            |
+| `destroyRegionFailures`                | Total number of destroyRegion attempts that have failed.                                      |
+| `destroyRegions`                       | Total number of destroyRegions that have completed successfully.                              |
+| `destroyRegionSendFailures`            | Total number of destroyRegionSends that have failed.                                          |
+| `destroyRegionSends`                   | Total number of destroyRegionSends that have completed successfully.                          |
+| `destroyRegionSendsInProgress`         | Current number of destroyRegionSends being executed.                                          |
+| `destroyRegionSendTime`                | Total amount of time, in nanoseconds, spent doing destroyRegionSends.                         |
+| `destroyRegionsInProgress`             | Current number of destroyRegions being executed.                                              |
+| `destroyRegionTime`                    | Total amount of time, in nanoseconds, spent doing destroyRegions.                             |
+| `destroyRegionTimeouts`                | Total number of destroyRegion attempts that have timed out.                                   |
+| `destroys`                             | Total number of destroys that have completed successfully.                                    |
+| `destroySendFailures`                  | Total number of destroySends that have failed.                                                |
+| `destroySends`                         | Total number of destroySends that have completed successfully.                                |
+| `destroySendsInProgress`               | Current number of destroySends being executed.                                                |
+| `destroySendTime`                      | Total amount of time, in nanoseconds, spent doing destroySends.                               |
+| `destroysInProgress`                   | Current number of destroys being executed.                                                    |
+| `destroyTime`                          | Total amount of time, in nanoseconds, spent doing destroys.                                   |
+| `destroyTimeouts`                      | Total number of destroy attempts that have timed out.                                         |
+| `disconnects`                          | Total number of times a connection has been destroyed.                                        |
+| `gatewayBatchFailures`                 | Total number of gatewayBatch attempts that have failed.                                       |
+| `gatewayBatchs`                        | Total number of gatewayBatchs completed successfully.                                         |
+| `gatewayBatchSendFailures`             | Total number of gatewayBatchSends that have failed.                                           |
+| `gatewayBatchSends`                    | Total number of gatewayBatchSends that have completed successfully.                           |
+| `gatewayBatchSendsInProgress`          | Current number of gatewayBatchSends being executed.                                           |
+| `gatewayBatchSendTime`                 | Total amount of time, in nanoseconds, spent doing gatewayBatchSends.                          |
+| `gatewayBatchsInProgress`              | Current number of gatewayBatchs being executed.                                               |
+| `gatewayBatchTime`                     | Total amount of time, in nanoseconds, spent doing gatewayBatchs.                              |
+| `gatewayBatchTimeouts`       

<TRUNCATED>