OpsCenter Metrics Tooltips Reference

Comprehensive reference of performance metrics available in OpsCenter.

Metrics are available to add to any graph. View descriptions of any metric by hovering over a metric in the Add Metric dialog, or by hovering over a graph legend.

The following list of metric descriptions available in tooltips is provided for your convenience:

Write Requests [write-ops]
The number of write requests per second on the coordinator nodes, analogous to client writes. Monitoring the number of requests over a given time period reveals system write workload and usage patterns.
Write Request Latency (percentiles) [write-histogram]
The min, median, max, 90th, and 99th percentiles of a client writes. The time period starts when a node receives a client write request, and ends when the node responds back to the client. Depending on consistency level and replication factor, this may include the network latency from writing to the replicas.
Write Failures [write-failures]
The number of write requests on the coordinator nodes that fail due to errors returned from replicas.
Write Timeouts [write-timeouts]
The number of server write timeouts per second on the coordinator nodes.
Write Unavailable Errors [write-unavailables]
The number of write requests per second on the coordinator nodes, that fail because not enough replicas are available.
Read Requests [read-ops]
The number of read requests per second on the coordinator nodes, analogous to client reads. Monitoring the number of requests over a given time period reveals system read workload and usage patterns.
Read Request Latency (percentiles) [read-histogram]
The min, median, max, 90th, and 99th percentiles of a client reads. The time period starts when a node receives a client read request, and ends when the node responds back to the client. Depending on consistency level and replication factor, this may include the network latency from requesting the data’s replicas.
Read Failures [read-failures]
The number of read requests on the coordinator nodes that fail due to errors returned from replicas.
Read Timeouts [read-timeouts]
The number of server read timeouts per second on the coordinator nodes.
Read Unavailable Errors [read-unavailables]
The number of read requests per second on the coordinator nodes, that fail because not enough replicas are available.
Non Heap Committed [nonheap-committed]
Allocated memory, guaranteed for Java nonheap.
Non Heap Max [nonheap-max]
Maximum amount that the Java nonheap can grow.
Non Heap Used [nonheap-used]
Average amount of Java nonheap memory used.
Heap Commited [heap-committed]
Allocated memory guaranteed for the Java heap.
Heap Max [heap-max]
Maximum amount that the Java heap can grow.
Heap Used [heap-used]
Average amount of Java heap memory used.
JVM CMS Collection Count [cms-collection-count]
Number of concurrent mark sweep garbage collections performed per second.
JVM ParNew Collection Count [par-new-collection-count]
Number of ParNew garbage collections performed per second. ParNew collections pause all work in the JVM but should finish quickly.
JVM CMS Collection Time [cms-collection-time]
Average number of milliseconds spent performing CMS garbage collections per second.
JVM ParNew Collection Time [par-new-collection-time]
Average number of milliseconds spent performing ParNew garbage collections per second. ParNew collections pause all work in the JVM but should finish quickly.
JVM G1 Old Collection Count [g1-old-collection-count]
Number of G1 old generation garbage collections performed per second.
JVM G1 Old Collection Time [g1-old-collection-time]
Average number of milliseconds spent performing G1 old generation garbage collections per second.
JVM G1 Young Collection Count [g1-young-collection-count]
Number of G1 young generation garbage collections performed per second.
JVM G1 Young Collection Time [g1-young-collection-time]
Average number of milliseconds spent performing G1 young generation garbage collections per second.
Data Size [data-load]
The live disk space used by all tables on a node.
Total Bytes Compacted [total-bytes-compacted]
Number of bytes compacted per second.
Total Compactions Completed [actual-total-compactions-completed]
Number of compaction tasks completed per second.
Total Compactions [total-compactions-completed]
Number of sstable scans per second that could result in a compaction.
Compactions Pending [pending-compaction-tasks]
Estimated number of compactions required to achieve the desired state. This includes the pending queue to the compaction executor and additional tasks that may be created from their completion.
Task Queues [all-pending]
Aggregate of thread pools pending queues that can be used to identify where things are backing up internally. This doesn't include pending compactions because it includes an estimate outside of the task queue or the hinted hand off queue, which can be in constant state of being on.
Dropped Messages: All [all-dropped]
Aggregate of all messages that have been dropped server-side due to not having been processed before their respective timeout.
Dropped Messages: Counter Mutations [dropped-counter-mutations]
Mutation was seen after the timeout (write_request_timeout_in_ms) so was thrown away. This client might have timed out before it met the required consistency level, but might have succeeded as well. Hinted handoffs and read repairs should resolve inconsistencies but a repair can ensure it.
Dropped Messages: Mutations [dropped-mutations]
Mutation was seen after the timeout (write_request_timeout_in_ms) so was thrown away. This client might have timed out before it met the required consistency level, but might have succeeded as well. Hinted handoffs and read repairs should resolve inconsistencies but a repair can ensure it.
Dropped Messages: Reads [dropped-reads]
A local read request was received after the timeout (read_request_timeout_in_ms) so it was thrown away because it would have already either been completed and sent to client or sent back as a timeout error.
Dropped Messages: Ranged Slice Reads [dropped-ranged-slice-reads]
A local ranged read request was received after the timeout (range_request_timeout_in_ms) so it was thrown away because it would have already either been completed and sent to client or sent back as a timeout error.
Dropped Messages: Read Repairs [dropped-read-repairs]
The Mutation was seen after the timeout (write_request_timeout_in_ms) so was thrown away. With the read repair timeout, the node still exists in an inconsistent state.
TP: Flushes Pending [pending-flushes]
Number of memtables queued for the flush process. A flush sorts and writes the memtables to disk.
TP: Gossip Tasks Pending [pending-gossip-stage]
Number of gossip messages and acknowledgments queued and waiting to be sent or received.
TP: Internal Responses Pending [pending-internal-response-stage]
Number of pending tasks from internal tasks, such as nodes joining and leaving the cluster.
TP: Manual Repair Tasks Pending [pending-anti-entropy-stage]
Repair tasks pending, such as handling the merkle tree transfer after the validation compaction.
TP: Cache Cleaning Pending [pending-cache-cleanup-stage]
Tasks pending to clean row caches during a cleanup compaction.
TP: Post Flushes Pending [pending-memtable-post-flush]
Tasks related to the last step in flushing memtables to disk as SSTables. Includes removing unnecessary commitlog files and committing Solr-based secondary indexes.
TP: Migrations Pending [pending-migration-stage]
Number of pending tasks from system methods that modified the schema.
TP: Misc. Tasks Pending [pending-misc-stage]
Number of pending tasks from infrequently run operations, such as taking a snapshot or processing the notification of a completed replication.
TP: Read Repair Tasks Pending [pending-read-repair-stage]
Number of read repair operations in the queue waiting to run.
TP: Request Responses Pending [pending-request-response-stage]
Number of pending callbacks to execute after a task on a remote node completes.
TP: Validation Executor Pending [pending-validation-executor]
Pending task to read data from sstables and generate a merkle tree for a repair.
TP: Compaction Executor Pending [pending-compaction-executor]
Pending compactions that are known. This metric could deviate from "pending compactions," which includes an estimate of tasks that these pending tasks might create after completion.
TP: Pending Range Calculator Pending [pending-pending-range-calculator]
Pending tasks to calculate the ranges according to bootstrapping and leaving nodes.
TP: Flushes Active [active-flushes]
Up to memtable_flush_writers concurrent tasks to flush and write the memtables to disk.
TP: Gossip Tasks Active [active-gossip-stage]
Number of gossip messages and acknowledgments actively being sent or received.
TP: Internal Responses Active [active-internal-response-stage]
Number of active tasks from internal tasks, such as nodes joining and leaving the cluster.
TP: Manual Repair Tasks Active [active-anti-entropy-stage]
Repair tasks active, such as handling the merkle tree transfer after the validation compaction.
TP: Cache Cleaning Active [active-cache-cleanup-stage]
Tasks to clean row caches during a cleanup compaction.
TP: Post Flushes Active [active-memtable-post-flush]
Tasks related to the last step in flushing memtables to disk as SSTables. Includes removing unnecessary commitlog files and committing Solr-based secondary indexes.
TP: Migrations Active [active-migration-stage]
Number of active tasks from system methods that modified the schema.
TP: Misc. Tasks Active [active-misc-stage]
Number of active tasks from infrequently run operations, such as taking a snapshot or processing the notification of a completed replication.
TP: Read Repair Tasks Active [active-read-repair-stage]
Number of read repair operations actively being run.
TP: Request Responses Active [active-request-response-stage]
Number of callbacks to being executed after a task on a remote node is completed.
TP: Validation Executor Active [active-validation-executor]
Active task to read data from sstables and generate a merkle tree for a repair.
TP: Compaction Executor Active [active-compaction-executor]
Active compactions that are known.
TP: Pending Range Calculator Active [active-pending-range-calculator]
Active tasks to calculate the ranges according to bootstrapping and leaving nodes.
TP: Flushes Completed [completed-flushes]
Number of memtables flushed to disk since the nodes start.
TP: Gossip Tasks Completed [completed-gossip-stage]
Number of gossip messages and acknowledgments recently sent or received.
TP: Internal Responses Completed [completed-internal-response-stage]
Number of recently completed tasks from internal tasks, such as nodes joining and leaving the cluster.
TP: Manual Repair Tasks Completed [completed-anti-entropy-stage]
Repair tasks recently completed, such as handling the merkle tree transfer after the validation compaction.
TP: Cache Cleaning Completed [completed-cache-cleanup-stage]
Tasks to clean row caches during a cleanup compaction.
TP: Post Flushes Completed [completed-memtable-post-flush]
Tasks related to the last step in flushing memtables to disk as SSTables. Includes removing unnecessary commitlog files and committing Solr-based secondary indexes.
TP: Migrations Completed [completed-migration-stage]
Number of completed tasks from system methods that modified the schema.
TP: Misc. Tasks Completed [completed-misc-stage]
Number of completed tasks from infrequently run operations, such as taking a snapshot or processing the notification of a completed replication.
TP: Read Repair Tasks Completed [completed-read-repair-stage]
Number of read repair operations recently completed.
TP: Request Responses Completed [completed-request-response-stage]
Number of completed callbacks executed after a task on a remote node is completed.
TP: Validation Executor Completed [completed-validation-executor]
Completed tasks to read data from sstables and generate a merkle tree for a repair.
TP: Compaction Executor Completed [completed-compaction-executor]
Completed compactions.
TP: Pending Range Calculator Completed [completed-pending-range-calculator]
Completed tasks to calculate the ranges according to bootstrapping and leaving nodes.
KeyCache Hits [key-cache-hits]
The number of key cache hits per second. This will avoid possible disk seeks when finding a partition in an SSTable. This metric only applies to SSTables created by DSE versions earlier than 6.0.
KeyCache Requests [key-cache-requests]
The number of key cache requests per second. This metric only applies to SSTables created by DSE versions earlier than 6.0.
KeyCache Hit Rate [key-cache-hit-rate]
The percentage of key cache lookups that resulted in a hit. This metric only applies to SSTables created by DSE versions earlier than 6.0.
RowCache Hits [row-cache-hits]
The number of row cache hits per second.
RowCache Requests [row-cache-requests]
The number of row cache requests per second.
RowCache Hit Rate [row-cache-hit-rate]
The percentage of row cache lookups that resulted in a hit.
Native Clients [native-connections]
The number of clients connected using the native protocol.
Read Repairs Attempted [read-repair-attempted]
Number of read requests where the number of nodes queried possibly exceeds the consistency level requested in order to check for a possible digest mismatch.
Asynchronous Read Repairs [read-repaired-background]
Corresponds to a digest mismatch that occurred after a completed read, outside of the client read loop.
Synchronous Read Repairs [read-repaired-blocking]
Corresponds to the number of times there was a digest mismatch within the requested consistency level and a full data read was started.
TBL: Local Writes [cf-write-ops]
Local write requests per second. Local writes update the table's memtable and appends to a commitlog.
TBL: Local Write Latency (percentiles) [cf-local-write-latency]
The min, median, max, 90th, and 99th percentile of the response times to write data to a table's memtable. The elapsed time from when the replica receives the request from a coordinator and returns a response.
TBL: Local Reads [cf-read-ops]
Local read requests per second. Local reads retrieve data from a table's memtable and any necessary SSTables on disk.
TBL: Local Read Latency (percentiles) [cf-local-read-latency]
The min, median, max, 90th, and 99th percentile of the response time to read data from the memtable and sstables for a specific table. The elapsed time from when the replica receives the request from a coordinator and returns a response.
TBL: Live Disk Used [cf-live-disk-used]
Disk space used by live SSTables. There might be obsolete SSTables not included.
TBL: Total Disk Used [cf-total-disk-used]
Disk space used by a table by SSTables, including obsolete ones waiting to be garbage collected.
TBL: SSTable Count [cf-live-sstables]
Total number of SSTables for a table.
TBL: SSTables per Read (percentiles) [cf-sstables-per-read]
The min, median, max, 90th, and 99th percentile of how many SSTables are accessed during a read. Includes sstables that undergo bloom-filter checks, even if no data is read from the sstable.
TBL: Partition Size (percentiles) [cf-partition-size]
The min, median, max, 90th, and 99th percentile of the size (in bytes) of partitions of this table.
TBL: Cell Count (percentiles) [cf-column-count]
The min, median, max, 90th, and 99th percentile of how many cells exist in partitions for this table.
TBL: Bloom Filter Space Used [cf-bf-space-used]
The total size of all the SSTables' bloom filters for this table.
TBL: Bloom Filter False Positives [cf-bf-false-positives]
Number of bloom filter false positives per second.
TBL: Bloom Filter False Positive Ratio [cf-bf-false-ratio]
Percentage of bloom filter lookups that resulted in a false positive.
Search: Requests [solr-requests]
Requests per second made to a specific Solr core/index.
Search: Request Latency [solr-avg-time-per-req]
Average time a search query takes in a DSE cluster using DSE Search.
Search: Errors [solr-errors]
Errors per second that occur for a specific Solr core/index.
Search: Timeouts [solr-timeouts]
Timeouts per second on a specific Solr core/index.
Search: Core Size [solr-index-size]
Size of the Solr core on disk.
OS: Memory (stacked) [os-memory]
Stacked graph of used, cached, and free memory.
OS: Memory (stacked) [os-memory-osx]
Stacked graph of used and free memory.
OS: Memory Free [os-memory-free]
Total system memory currently free.
OS: Memory Used [os-memory-used]
Total system memory currently used.
OS: Memory Shared [os-memory-shared]
Total amount of memory in shared memory space.
OS: Memory Buffered [os-memory-buffers]
Total system memory currently buffered.
OS: Memory Cached [os-memory-cached]
Total system memory currently cached.
OS: Memory (stacked) [os-memory-win]
Stacked graph of committed, cached, paged, non-paged, and free memory.
OS: Memory Available [os-memory-avail]
Available physical memory.
OS: Memory Committed [os-memory-committed]
Memory in use by the operating system.
OS: Pool Paged Resident Memory [os-memory-pool-paged]
Allocated pool-paged-resident memory.
OS: Pool Nonpaged Memory [os-memory-pool-nonpaged]
Allocated pool-nonpaged memory.
OS: System Cache Resident Memory [os-memory-sys-cache-resident]
Memory used by the file cache.
OS: CPU (stacked) [cpu]
Stacked graph of iowait, steal, nice, system, user, and idle CPU usage.
OS: CPU (stacked) [cpu-osx]
Stacked graph of idle, user, and system CPU usage.
OS: CPU (stacked) [cpu-win]
Stacked graph of user, privileged, and idle CPU usage.
OS: CPU User [os-cpu-user]
Time the CPU devotes to user processes.
OS: CPU System [os-cpu-system]
Time the CPU devotes to system processes.
OS: CPU Idle [os-cpu-idle]
Time the CPU is idle.
OS: CPU Iowait [os-cpu-iowait]
Time the CPU devotes to waiting for I/O to complete.
OS: CPU Steal [os-cpu-steal]
Time the CPU devotes to tasks stolen by virtual operating systems.
OS: CPU Nice [os-cpu-nice]
Time the CPU devotes to processing nice tasks.
OS: CPU Privileged [os-cpu-privileged]
Time the CPU devotes to processing privileged instructions.
OS: Load [os-load]
Operating system load average. One minute value parsed from /proc/loadavg on Linux systems.
OS: Disk Usage (%) [os-disk-usage]
Disk space used by Cassandra at a given time.
OS: Disk Free [os-disk-free]
Free space on a specific disk partition.
OS: Disk Used [os-disk-used]
Disk space used by Cassandra at a given time.
OS: Disk Read Throughput [os-disk-read-throughput]
Average disk throughput for read operations.
OS: Disk Write Throughput [os-disk-write-throughput]
Average disk throughput for write operations.
OS: Disk Throughput [os-disk-throughput]
Average disk throughput for read and write operations.
OS: Disk Read Rate [os-disk-read-rate]
Rate of reads per second to the disk.
OS: Disk Writes Rate [os-disk-write-rate]
Rate of writes per second to the disk.
OS: Disk Latency [os-disk-await]
Average completion time of each request to the disk.
OS: Disk Request Size [os-disk-request-size]
Average size of read requests issued to the disk.
OS: Disk Request Size [os-disk-request-size-kb]
Average size of read requests issued to the disk.
OS: Disk Queue Size [os-disk-queue-size]
Average number of requests queued due to disk latency issues.
OS: Disk Utilization [os-disk-utilization]
CPU time consumed by disk I/O.
OS: Net Received [os-net-received]
Speed of data received from the network.
OS: Net Sent [os-net-sent]
Speed of data sent across the network.
OS: Net Sent [os-net-sent-win]
Speed of data sent across the network.
OS: Net Received [os-net-received-win]
Speed of data received from the network.
Speculative Retries [speculative-retries]
Number of speculative retries for all column families.
TBL: Speculative Retries [cf-speculative-retries]
Number of speculative retries for this table.
Stream Data Out - Total [stream-out-total]
Data streamed out from this node to all other nodes, for all tables.
Stream Data In - Total [stream-in-total]
Data streams in to this node from all other nodes, for all tables.
Hint Creation Rate [hint-creation-rate]
Rate at which new individual hints are stored on this node, to be replayed to peers.
TBL: Bloom Filter Off Heap [cf-bf-offheap]
Total off heap memory used by bloom filters from all live SSTables in a table.
TBL: Index Summary Off Heap [cf-index-summary-offheap]
Total off heap memory used by the index summary of all live SSTables in a table.
TBL: Compression Metadata Off Heap [cf-compression-data-offheap]
Total off heap memory used by the compression metadata of all live SSTables in a table.
TP: Memtable Reclaims Pending [memtable-reclaim-pending]
Waits for current reads to complete and then frees the memory formerly used by the obsoleted memtables.
TP: Memtable Reclaims Active [memtable-reclaim-active]
Waits for current reads to complete and then frees the memory formerly used by the obsoleted memtables.
TP: Memtable Reclaims Completed [completed-memtable-reclaim]
Waits for current reads to complete and then frees the memory formerly used by the obsoleted memtables.
TBL: Memtable Off Heap [cf-memtable-offheap]
Off heap memory used by a table's current memtable.
TBL: Total Memtable Heap Size [cf-all-memtables-heapsize]
An estimate of the space used in JVM heap memory for all memtables. This includes ones that are currently being flushed and related secondary indexes.
TBL: Total Memtable Live Data Size [cf-all-memtables-livedatasize]
An estimate of the space used for 'live data' (off-heap, excluding overhead) for all memtables. This includes ones that are currently being flushed and related secondary indexes.
TBL: Total Memtable Off-Heap Size [cf-all-memtables-offheapsize]
An estimate of the space used in off-heap memory for all memtables. This includes ones that are currently being flushed and related secondary indexes.
In-Memory Percent Used [in-memory-percent-used]
The percentage of memory allocated for in-memory tables currently in use.
TBL: Partition Count [cf-row-size]
Approximate number of partitions. This may be off given duplicates in memtables and sstables are both counted and there is a very small error percentage inherited from the HyperLogLog data structure.
Write Request Latency [write-latency-legacy]
Deprecated. The median response times (in milliseconds) of a client write. The time period starts when a node receives a client write request, and ends when the node responds back to the client. Depending on consistency level and replication factor, this may include the network latency from writing to the replicas.
Read Request Latency [read-latency-legacy]
Deprecated. The median response times (in milliseconds) of a client read. The time period starts when a node receives a client read request, and ends when the node responds back to the client. Depending on consistency level and replication factor, this may include the network latency from requesting the data's replicas.
View Write Latency (percentiles) [view-write-histogram]
The min, median, max, 90th, and 99th percentiles of the time from when base mutation is applied to memtable until CL.ONE is achieved on the async write to the tables materialized views. An estimate to determine the lag between base table mutations and the views consistency.
View Write Successes [view-replicas-success]
Number of view mutations sent to replicas that have been acknowledged.
View Write Pending [view-replicas-pending]
Number of view mutations sent to replicas where the replicas acknowledgement hasn't been received.
TP: Hint Dispatcher Pending [pending-hint-dispatcher]
Pending tasks to send the stored hinted handoffs to a host.
TP: Hint Dispatcher Active [active-hint-dispatcher]
Up to max_hints_delivery_threads tasks, each dispatching all hinted handoffs to a host.
TP: Hint Dispatcher Completed [completed-hint-dispatcher]
Number of tasks to transfer hints to a host that have completed.
TP: Index Management Pending [pending-secondary-index-management]
Any initialization work when a new index instance is created. This may involve costly operations such as (re)building the index.
TP: Index Management Active [active-secondary-index-management]
Any initialization work when a new index instance is created. This may involve costly operations such as (re)building the index.
TP: Index Management Completed [completed-secondary-index-management]
Any initialization work when a new index instance is created. This may involve costly operations such as (re)building the index.
TBL: Tombstones per Read (percentiles) [cf-tombstones-per-read]
The min, median, max, 90th, and 99th percentile of how many tombstones are read during a read.
TBL: Local Write Latency [cf-write-latency-legacy]
Deprecated. Median response time to write data to a table's memtable. The elapsed time from when the replica receives the request from a coordinator and returns a response.
TBL: Local Read Latency [cf-read-latency-legacy]
Deprecated. Median response time to read data from the memtable and SSTables for a specific table. The elapsed time from when the replica receives the request from a coordinator and returns a response.
TBL: Coordinator Read Latency (percentiles) [cf-coordinator-read-latency]
The min, median, max, 90th, and 99th percentiles of client reads on this table. The time period starts when a node receives a client read request, and ends when the node responds back to the client. Depending on consistency level and replication factor, this may include the network latency from requesting the data's replicas.
TBL: Coordinator Read Requests [cf-coordinator-read-ops]
The number of read requests per second for a particular table on the coordinator nodes. Monitoring the number of requests over a given time period reveals table read workload and usage patterns.
Cells Scanned (percentiles) [cells-scanned-during-read]
The min, median, max, 90th, and 99th percentile of how many cells were scanned during a read.
TBL: Cells Scanned (percentiles) [cf-cells-scanned-during-read]
The min, median, max, 90th, and 99th percentile of how many cells were scanned during a read.
TIER: Total Disk Used [cf-tier-size]
Disk space used by a table by SSTables for the tier.
TIER: sstables [cf-tier-sstables]
Number of SSTables in a tier for a table.
TIER: Max Data Age [cf-tier-max-data-age]
Timestamp in local server time that represents an upper bound to the newest piece of data stored in the SSTable. When a new SSTable is flushed, it is set to the time of creation. When an SSTable is created from compaction, it is set to the max of all merged SSTables.
Graph: Adjacency Cache Hits [graph-adjacency-cache-hit]
Number of hits against the adjacency cache for this graph.
Graph: Adjacency Cache Misses [graph-adjacency-cache-miss]
Number of misses against the adjacency cache for this graph.
Graph: Index Cache Hits [graph-index-cache-hit]
Number of hits against the index cache for this graph.
Graph: Index Cache Misses [graph-index-cache-miss]
Number of misses against the index cache for this graph.
Graph: Request Latencies [graph-request-latencies]
The min, median, max, 90th, and 99th percentile of request latencies during the period.
Graph TP: Graph Scheduled Threads Pending [pending-graph-scheduled-threads]
Number of pending tasks in the GraphScheduledThreads thread pool.
Graph TP: Graph Scheduled Threads Active [active-graph-scheduled-threads]
Number of active tasks in the GraphScheduledThreads thread pool.
Graph TP: Graph Scheduled Threads Completed [completed-graph-scheduled-threads]
Number of tasks completed by the GraphScheduledThreads thread pool.
Graph TP: Graph System Threads Pending [pending-graph-system-threads]
Number of pending tasks in the GraphSystemThreads thread pool.
Graph TP: Graph System Threads Active [active-graph-system-threads]
Number of active tasks in the GraphSystemThreads thread pool.
Graph TP: Graph System Threads Completed [completed-graph-system-threads]
Number of tasks completed by the GraphSystemThreads thread pool.
Graph TP: Gremlin Worker Threads Pending [pending-gremlin-worker-threads]
Number of pending tasks in the GremlinWorkerThreads thread pool.
Graph TP: Gremlin Worker Threads Active [active-gremlin-worker-threads]
Number of active tasks in the GremlinWorkerThreads thread pool.
Graph TP: Gremlin Worker Threads Completed [completed-gremlin-worker-threads]
Number of tasks completed by the GremlinWorkerThreads thread pool.
Percent Data Repaired [percentage-repaired]
Percentage of data (uncompressed) marked as repaired across all non-system tables on a node. Tables with a replication factor of 1 are excluded.
TBL: Percent Data Repaired [cf-percentage-repaired]
Percentage of data (uncompressed) marked as repired for a given table on a node. This metric is only meaningful for replication factor > 1.
Read Requests - Local Node Non Replica [read-coordinator-nonreplica]
Rate of coordinated reads to a node where that node is not a replica for that partition.
Read Requests - Preferred Other Replicas [read-coordinator-preferother]
Rate of coordinated reads to a node where that node did not choose itself as a replica for the read request.
Hints on Disk [hints-on-disk]
The number of hints currently stored on disk, to be replayed to peers.
Hint Replay Success Rate [hint-replay-success-rate]
Rate of successful individual hint replays to peers. If one or more individual hints fail to replay in a batch, the successful hints in that batch will be replayed again and double counted in this metric.
Hint Replay Error Rate [hint-replay-error-rate]
Rate of failed individual hint replays. Replay of a single hint can fail more than once if retried.
Hint Replay Timeout Rate [hint-replay-timeout-rate]
Rate of timed out individual hint replays. Replay of a single hint can timeout more than once if retried.
Hint Replay Received Rate [hint-replay-received-rate]
Rate of successful individual hints replayed to this node, from other peers.
Node Messaging Latency [cross-node-latency]
The min, median, max, 90th, and 99th percentiles of the latency of messages between nodes. The time period starts when a node sends a message and ends when the current node receives it.
Datacenter Messaging Latency [cross-dc-latency]
The min, median, max, 90th, and 99th percentiles of the message latency between nodes in the same or different destination datacenter. This metric measures how long it takes a message from a node in the source datacenter to reach a node in the destination datacenter. Selecting a destination node within the source datacenter yields lower latency values.
NodeSync: Data Repaired [nodesync-data-repaired]
Bytes of data that were inconsistent and needed synchronization.
NodeSync: Data Validated [nodesync-data-validated]
Bytes of data checked for consistency.
NodeSync: Repair Data Sent [nodesync-repair-data-sent]
Total bytes of data transferred between all nodes during synchronization.
NodeSync: Objects Repaired [nodesync-objects-repaired]
Number of rows and range tombstones that were inconsistent and needed synchronization.
NodeSync: Objects Validated [nodesync-objects-validated]
Number of rows and range tombstones checked for consistency.
NodeSync: Repair Objects Sent [nodesync-repair-objects-sent]
Total number of rows and range tombstones transferred between all nodes during synchronization.
NodeSync: Processed Pages [nodesync-processed-pages]
Number of pages (internal groupings of data) processed.
NodeSync: Full In Sync Pages [nodesync-full-in-sync-pages]
Number of processed pages that were not in need of synchronization.
NodeSync: Full Repaired Pages [nodesync-full-repaired-pages]
Number of processed pages that were in need of synchronization.
NodeSync: Partial In Sync Pages [nodesync-partial-in-sync-pages]
Number of in sync pages for which a response was gotten from only a partial number of replicas.
NodeSync: Partial Repaired Pages [nodesync-partial-repaired-pages]
Number of repaired pages for which a response was gotten from only a partial number of replicas.
NodeSync: Uncompleted Pages [nodesync-uncompleted-pages]
Number of processed pages not having enough responses to perform synchronization.
NodeSync: Failed Pages [nodesync-failed-pages]
Number of processed pages for which an unknown error prevented proper synchronization completion.
NodeSync TBL: Data Repaired [nodesync-tbl-data-repaired]
Bytes of data that were inconsistent and needed synchronization.
NodeSync TBL: Data Validated [nodesync-tbl-data-validated]
Bytes of data checked for consistency.
NodeSync TBL: Repair Data Sent [nodesync-tbl-repair-data-sent]
Total bytes of data transferred between all nodes during synchronization.
NodeSync TBL: Objects Repaired [nodesync-tbl-objects-repaired]
Number of rows and range tombstones that were inconsistent and needed synchronization.
NodeSync TBL: Objects Validated [nodesync-tbl-objects-validated]
Number of rows and range tombstones checked for consistency.
NodeSync TBL: Repair Objects Sent [nodesync-tbl-repair-objects-sent]
Total number of rows and range tombstones transferred between all nodes during synchronization.
NodeSync TBL: Processed Pages [nodesync-tbl-processed-pages]
Number of pages (internal groupings of data) processed.
NodeSync TBL: Full In Sync Pages [nodesync-tbl-full-in-sync-pages]
Number of processed pages that were not in need of synchronization.
NodeSync TBL: Full Repaired Pages [nodesync-tbl-full-repaired-pages]
Number of processed pages that were in need of synchronization.
NodeSync TBL: Partial In Sync Pages [nodesync-tbl-partial-in-sync-pages]
Number of in sync pages for which a response was gotten from only a partial number of replicas.
NodeSync TBL: Partial Repaired Pages [nodesync-tbl-partial-repaired-pages]
Number of repaired pages for which a response was gotten from only a partial number of replicas.
NodeSync TBL: Uncompleted Pages [nodesync-tbl-uncompleted-pages]
Number of processed pages not having enough responses to perform synchronization.
NodeSync TBL: Failed Pages [nodesync-tbl-failed-pages]
Number of processed pages for which an unknown error prevented proper synchronization completion.
TP: Authentication Active [active-authentication]
Authentication Active
TP: Authentication Completed [completed-authentication]
Authentication Completed
TP: Execute Statement Active [active-execute-statement]
Execute Statement Active
TP: Execute Statement Completed [completed-execute-statement]
Execute Statement Completed
TP: Unknown Active [active-unknown]
Unknown Active
TP: Unknown Completed [completed-unknown]
Unknown Completed
TP: Truncate Active [active-truncate]
Truncate Active
TP: Truncate Completed [completed-truncate]
Truncate Completed
TP: Counter Acquire Lock Active [active-counter-acquire-lock]
Counter Acquire Lock Active
TP: Counter Acquire Lock Completed [completed-counter-acquire-lock]
Counter Acquire Lock Completed
TP: CAS Active [active-cas]
CAS Active
TP: CAS Completed [completed-cas]
CAS Completed
TP: Write Switch For Memtable Active [active-write-switch-for-memtable]
Write Switch For Memtable Active
TP: Write Switch For Memtable Completed [completed-write-switch-for-memtable]
Write Switch For Memtable Completed
TP: Read Disk Async Active [active-read-disk-async]
Read Disk Async Active
TP: Read Disk Async Completed [completed-read-disk-async]
Read Disk Async Completed
TP: Timed Unknown Active [active-timed-unknown]
Timed Unknown Active
TP: Timed Unknown Completed [completed-timed-unknown]
Timed Unknown Completed
TP: Timed Timeout Active [active-timed-timeout]
Timed Timeout Active
TP: Timed Timeout Completed [completed-timed-timeout]
Timed Timeout Completed
TP: Write Defragment Active [active-write-defragment]
Write Defragment Active
TP: Write Defragment Completed [completed-write-defragment]
Write Defragment Completed
TP: Read Secondary Index Active [active-read-secondary-index]
Read Secondary Index Active
TP: Read Secondary Index Completed [completed-read-secondary-index]
Read Secondary Index Completed
TP: Write Defragment Total Blocked [total-blocked-write-defragment]
Total Write Defragment Blocked
TP: Write Defragment Pending [pending-write-defragment]
Write Defragment Pending
TP: View Build Executor Active [active-view-build-executor]
View Build Executor Active
TP: View Build Executor Completed [completed-view-build-executor]
View Build Executor Completed
TP: View Build Executor Pending [pending-view-build-executor]
View Build Executor Pending
TP: Background IO Stage Active [active-background-io-stage]
Background IO Stage Active
TP: Background IO Stage Completed [completed-background-io-stage]
Background IO Stage Completed
TP: Background IO Stage Pending [pending-background-io-stage]
Background IO Stage Pending
TP: Repair Tasks Active [active-repair-task]
Repair Tasks Active
TP: Repair Tasks Completed [completed-repair-task]
Repair Tasks Completed
TP: Repair Tasks Pending [pending-repair-task]
Repair Tasks Pending
TP: Auth Stage Active [active-auth-stage]
Auth Stage Active
TP: Auth Stage Completed [completed-auth-stage]
Auth Stage Completed
TP: Auth Stage Pending [pending-auth-stage]
Auth Stage Pending
TP: Frame Decode Total Blocked [total-blocked-frame-decode]
Total Frame Decode Blocked
TP: Write Remote Total Blocked [total-blocked-write-remote]
Total Write Remote Blocked
TP: Frame Decode Completed [completed-frame-decode]
Frame Decode Completed
TP: Read Local Pending [pending-read-local]
Read Local Pending
TP: Write Remote Completed [completed-write-remote]
Write Remote Completed
TP: Read Remote Pending [pending-read-remote]
Read Remote Pending
TP: Read Range Remote Pending [pending-read-range-remote]
Read Range Remote Pending
TP: Read Range Local Completed [completed-read-range-local]
Read Range Local Completed
TP: Write Local Pending [pending-write-local]
Write Local Pending
TP: Read Range Nodesync Active [active-read-range-nodesync]
Read Range Nodesync Active
TP: Network Backpressure Active [active-network-backpressure]
Network Backpressure Active
TP: Read Range Nodesync Completed [completed-read-range-nodesync]
Read Range Nodesync Completed
TP: Read Local Active [active-read-local]
Read Local Active
TP: Read Timeout Completed [completed-read-timeout]
Read Timeout Completed
TP: Read Internal Completed [completed-read-internal]
Read Internal Completed
TP: Read Local Completed [completed-read-local]
Read Local Completed
TP: Read Range Local Total Blocked [total-blocked-read-range-local]
Total Read Range Local Blocked
TP: Read Range Internal Completed [completed-read-range-internal]
Read Range Internal Completed
TP: Hint Dispatch Active [active-hint-dispatch]
Hint Dispatch Active
TP: Write Internal Active [active-write-internal]
Write Internal Active
TP: Hint Response Completed [completed-hint-response]
Hint Response Completed
TP: Write Internal Completed [completed-write-internal]
Write Internal Completed
TP: Read Speculate Active [active-read-speculate]
Read Speculate Active
TP: Network Backpressure Completed [completed-network-backpressure]
Network Backpressure Completed
TP: Read Range Remote Completed [completed-read-range-remote]
Read Range Remote Completed
TP: Read Timeout Active [active-read-timeout]
Read Timeout Active
TP: Read Internal Active [active-read-internal]
Read Internal Active
TP: Read Speculate Completed [completed-read-speculate]
Read Speculate Completed
TP: Hint Dispatch Completed [completed-hint-dispatch]
Hint Dispatch Completed
TP: Write Local Completed [completed-write-local]
Write Local Completed
TP: Read Range Remote Total Blocked [total-blocked-read-range-remote]
Total Read Range Remote Blocked
TP: Hint Dispatch Total Blocked [total-blocked-hint-dispatch]
Total Hint Dispatch Blocked
TP: Read Local Total Blocked [total-blocked-read-local]
Total Read Local Blocked
TP: Read Range Internal Active [active-read-range-internal]
Read Range Internal Active
TP: Read Remote Active [active-read-remote]
Read Remote Active
TP: Write Remote Active [active-write-remote]
Write Remote Active
TP: Frame Decode Active [active-frame-decode]
Frame Decode Active
TP: Read Range Local Active [active-read-range-local]
Read Range Local Active
TP: Network Backpressure Pending [pending-network-backpressure]
Network Backpressure Pending
TP: Write Local Active [active-write-local]
Write Local Active
TP: Read Range Local Pending [pending-read-range-local]
Read Range Local Pending
TP: Hint Response Active [active-hint-response]
Hint Response Active
TP: Read Range Nodesync Total Blocked [total-blocked-read-range-nodesync]
Total Read Range Nodesync Blocked
TP: Read Range Remote Active [active-read-range-remote]
Read Range Remote Active
TP: Network Backpressure Total Blocked [total-blocked-network-backpressure]
Total Network Backpressure Blocked
TP: Write Local Total Blocked [total-blocked-write-local]
Total Write Local Blocked
TP: Frame Decode Pending [pending-frame-decode]
Frame Decode Pending
TP: Write Remote Pending [pending-write-remote]
Write Remote Pending
TP: Read Range Nodesync Pending [pending-read-range-nodesync]
Read Range Nodesync Pending
TP: Hint Dispatch Pending [pending-hint-dispatch]
Hint Dispatch Pending
TP: Read Remote Total Blocked [total-blocked-read-remote]
Total Read Remote Blocked
TP: Read Remote Completed [completed-read-remote]
Read Remote Completed
TP: Eventloop Spin Active [active-eventloop-spin]
Eventloop Spin Active
TP: Read Deferred Completed [completed-read-deferred]
Read Deferred Completed
TP: Authorization Completed [completed-authorization]
Authorization Completed
TP: Batch Replay Completed [completed-batch-replay]
Batch Replay Completed
TP: Write Await Commitlog Segment Active [active-write-await-commitlog-segment]
Write Await Commitlog Segment Active
TP: Eventloop Park Active [active-eventloop-park]
Eventloop Park Active
TP: Read Switch For Response Active [active-read-switch-for-response]
Read Switch For Response Active
TP: NodeSync Validation Active [active-nodesync-validation]
NodeSync Validation Active
TP: Read Switch For Iterator Active [active-read-switch-for-iterator]
Read Switch For Iterator Active
TP: Batch Remove Active [active-batch-remove]
Batch Remove Active
TP: Batch Replay Active [active-batch-replay]
Batch Replay Active
TP: Read Range Switch For Response Active [active-read-range-switch-for-response]
Read Range Switch For Response Active
TP: Write Switch For Response Active [active-write-switch-for-response]
Write Switch For Response Active
TP: Batch Remove Completed [completed-batch-remove]
Batch Remove Completed
TP: Batch Store Response Completed [completed-batch-store-response]
Batch Store Response Completed
TP: Write Memtable Full Active [active-write-memtable-full]
Write Memtable Full Active
TP: Lwt Propose Pending [pending-lwt-propose]
Lwt Propose Pending
TP: Write Await Commitlog Sync Active [active-write-await-commitlog-sync]
Write Await Commitlog Sync Active
TP: NodeSync Validation Completed [completed-nodesync-validation]
NodeSync Validation Completed
TP: Lwt Commit Completed [completed-lwt-commit]
Lwt Commit Completed
TP: Read Switch For Response Completed [completed-read-switch-for-response]
Read Switch For Response Completed
TP: Eventloop Yield Active [active-eventloop-yield]
Eventloop Yield Active
TP: Lwt Prepare Active [active-lwt-prepare]
Lwt Prepare Active
TP: Lwt Propose Completed [completed-lwt-propose]
Lwt Propose Completed
TP: Batch Store Pending [pending-batch-store]
Batch Store Pending
TP: Read Switch For Iterator Completed [completed-read-switch-for-iterator]
Read Switch For Iterator Completed
TP: Lwt Prepare Pending [pending-lwt-prepare]
Lwt Prepare Pending
TP: Write Memtable Full Completed [completed-write-memtable-full]
Write Memtable Full Completed
TP: Truncate Pending [pending-truncate]
Truncate Pending
TP: Read Deferred Pending [pending-read-deferred]
Read Deferred Pending
TP: Eventloop Spin Completed [completed-eventloop-spin]
Eventloop Spin Completed
TP: Write Switch For Response Completed [completed-write-switch-for-response]
Write Switch For Response Completed
TP: Eventloop Park Completed [completed-eventloop-park]
Eventloop Park Completed
TP: Lwt Propose Active [active-lwt-propose]
Lwt Propose Active
TP: Lwt Prepare Completed [completed-lwt-prepare]
Lwt Prepare Completed
TP: Authorization Active [active-authorization]
Authorization Active
TP: Eventloop Yield Completed [completed-eventloop-yield]
Eventloop Yield Completed
TP: Batch Store Completed [completed-batch-store]
Batch Store Completed
TP: Batch Store Active [active-batch-store]
Batch Store Active
TP: Batch Remove Pending [pending-batch-remove]
Batch Remove Pending
TP: Lwt Commit Active [active-lwt-commit]
Lwt Commit Active
TP: Lwt Commit Pending [pending-lwt-commit]
Lwt Commit Pending
TP: Write Await Commitlog Segment Completed [completed-write-await-commitlog-segment]
Write Await Commitlog Segment Completed
TP: Read Range Switch For Response Completed [completed-read-range-switch-for-response]
Read Range Switch For Response Completed
TP: Batch Store Response Active [active-batch-store-response]
Batch Store Response Active
TP: Write Await Commitlog Sync Completed [completed-write-await-commitlog-sync]
Write Await Commitlog Sync Completed
TP: Read Deferred Active [active-read-deferred]
Read Deferred Active
TP: Batch Remove Total Blocked [total-blocked-batch-remove]
Total Batch Remove Blocked
TP: Read Deferred Total Blocked [total-blocked-read-deferred]
Total Read Deferred Blocked
TP: Lwt Commit Total Blocked [total-blocked-lwt-commit]
Total Lwt Commit Blocked
TP: Lwt Propose Total Blocked [total-blocked-lwt-propose]
Total Lwt Propose Blocked
TP: Truncate Total Blocked [total-blocked-truncate]
Total Truncate Blocked
TP: Lwt Prepare Total Blocked [total-blocked-lwt-prepare]
Total Lwt Prepare Blocked
TP: Batch Store Total Blocked [total-blocked-batch-store]
Total Batch Store Blocked
Dropped Messages: Materialized View Mutations [dropped-view-mutations]
Mutation of Materialized View was seen after the timeout (write_request_timeout_in_ms) so was thrown away. This client might have timed out before it met the required consistency level, but might have succeeded as well. Hinted handoffs and read repairs should resolve inconsistencies but a repair can ensure it.
Dropped Messages: Lightweight Transactions [dropped-lwt]
Lightweight Transaction was seen after the timeout (write_request_timeout_in_ms) so was thrown away. This client might have timed out before it met the required consistency level, but might have succeeded as well. Hinted handoffs and read repairs should resolve inconsistencies but a repair can ensure it.
Dropped Messages: Hinted Handoffs [dropped-hints]
Hinted Handoff was seen after the timeout (write_request_timeout_in_ms) so was thrown away. Repairing the data or using NodeSync, should resolve data inconsistencies.
Dropped Messages: Truncate Operations [dropped-truncates]
Truncate operation was seen after the timeout (truncate_request_timeout_in_ms) so was thrown away.
Dropped Messages: Snapshot Requests [dropped-snapshots]
Snapshot Request was seen after the timeout (request_timeout_in_ms) so was thrown away. Snapshot should be retried.
Dropped Messages: Schema Changes [dropped-schemas]
Schema change was seen after the timeout (request_timeout_in_ms) so was thrown away. Schema agreement may not have been reached immediately, but this will eventually resolve itself.
Dropped Messages: Repair Messages [dropped-repairs]
Repair message was seen after the timeout so was thrown away.
Dropped Messages: Miscellaneous [dropped-other]
Miscellaneous message was seen after the timeout so was thrown away.
Dropped Messages: NodeSync [dropped-node-sync]
NodeSync message was seen after the timeout so was thrown away.
Dropped Messages: Batch Store [dropped-batch-store]
Batch store message was seen after the timeout so was thrown away.