CockroachDB is a distributed SQL database built on a transactional and strongly-consistent key-value store. It scales horizontally, survives disk, machine, rack, and even datacenter failures with minimal latency disruption and no manual intervention. CockroachDB provides a familiar SQL API for structuring, manipulating, and querying data.
Prerequisite
For Virtual Machines, install the Linux Agent.
Configuring the credentials
Configure the credentials in the directory /opt/opsramp/agent/conf/app.d/creds.yaml
cockroachdb:
- name: cockroachdb
user: <username>
pwd: <Password>
encoding-type: plain
labels:
key1: val1
key2: val2
Configuring the application
Virtual machine
Configure the application in the directory /opt/opsramp/agent/conf/app/discovery/auto-detection.yaml
- name: cockroachdb
instance-checks:
service-check:
- cockroach
process-check:
- cockroach
port-check:
- 26257
- 8080
Docker environment
Configure the application in the directory /opt/opsramp/agent/conf/app/discovery/auto-container-detection.yaml
- name: cockroachdb
container-checks:
image-check:
- cockroach
port-check:
- 26257
- 8080
Kubernetes environment
Configure the application in config.yaml
- name: cockroachdb
container-checks:
image-check:
- cockroach
port-check:
- 26257
- 8080
Validate
Go to Resources under the Infrastructure tab to check if your resources are onboarded and the metrics are collected.
Metrics
OpsRamp Metric | Metric Display Name | Unit | Description |
---|---|---|---|
cockroachdb_addsstable_applications | Addsstable Applications | Operations / second | Number of SSTable ingestions applied (applied by Replicas) |
cockroachdb_addsstable_copies | Addsstable Copies | Operations / second | Number of SSTable ingestions that required copying files during application |
cockroachdb_addsstable_proposals | Addsstable Proposals | Operations / second | Number of SSTable ingestions proposed (sent to Raft by lease holders) |
cockroachdb_build_timestamp | Build Timestamp | Time | Build information |
cockroachdb_capacity_available | Capacity Available | bytes | Available storage capacity |
cockroachdb_capacity_reserved | Capacity Reserved | bytes | Capacity reserved for snapshots |
cockroachdb_capacity_total | Capacity Total | bytes | Total storage capacity |
cockroachdb_capacity_used | Capacity Used | bytes | Used storage capacity |
cockroachdb_clock_offset_meannanos | Clock Offset Meannanos | nanoseconds | Mean clock offset with other nodes |
cockroachdb_clock_offset_stddevnanos | Clock Offset Stddevnanos | nanoseconds | Stdddev clock offset with other nodes |
cockroachdb_compactor_compactingnanos | Compactor Compactingnanos | nanoseconds / second | Time spent compacting ranges |
cockroachdb_compactor_compactions_failure | Compactor Compactions Failure | Requests / second | Number of failed compaction requests sent to the storage engine |
cockroachdb_compactor_compactions_success | Compactor Compactions Success | Requests / second | Number of successful compaction requests sent to the storage engine |
cockroachdb_compactor_suggestionbytes_compacted | Compactor Suggestionbytes Compacted | bytes / second | Number of logical bytes compacted from suggested compactions |
cockroachdb_compactor_suggestionbytes_queued | Compactor Suggestionbytes Queued | bytes | Number of logical bytes in suggested compactions in the queue |
cockroachdb_compactor_suggestionbytes_skipped | Compactor Suggestionbytes Skipped | bytes / second | Number of logical bytes in suggested compactions that were not compacted |
cockroachdb_distsender_batches_partial | Distsender Batches Partial | per second | Number of partial batches processed |
cockroachdb_distsender_batches_total | Distsender Batches Total | per second | Number of batches processed |
cockroachdb_distsender_errors_notleaseholder | Distsender Errors Notleaseholder | Errors / second | Number of NotLeaseHolderErrors encountered |
cockroachdb_distsender_rpc_sent_local | Distsender Rpc Sent Local | per second | Number of local RPCs sent |
cockroachdb_distsender_rpc_sent_nextreplicaerror | Distsender Rpc Sent Nextreplicaerror | Errors / second | Number of RPCs sent due to per-replica errors |
cockroachdb_distsender_rpc_sent_total | Distsender Rpc Sent Total | per second | Number of RPCs sent |
cockroachdb_exec_error | Exec Error | Requests / second | Number of batch KV requests that failed to execute on this node |
cockroachdb_exec_latency | Exec Latency | nanoseconds | Average Latency of batch KV requests executed on this node since last pool |
cockroachdb_exec_success | Exec Success | Requests / second | Number of batch KV requests executed successfully on this node |
cockroachdb_gcbytesage | Gcbytesage | seconds | Cumulative age of non-live data |
cockroachdb_gossip_bytes_received | Gossip Bytes Received | bytes / second | Number of received gossip bytes |
cockroachdb_gossip_bytes_sent | Gossip Bytes Sent | bytes / second | Number of sent gossip bytes |
cockroachdb_gossip_connections_incoming | Gossip Connections Incoming | Connections | Number of active incoming gossip connections |
cockroachdb_gossip_connections_outgoing | Gossip Connections Outgoing | Connections | Number of active outgoing gossip connections |
cockroachdb_gossip_connections_refused | Gossip Connections Refused | Connections / second | Number of refused incoming gossip connections |
cockroachdb_gossip_infos_received | Gossip Infos Received | per second | Number of received gossip Info objects |
cockroachdb_gossip_infos_sent | Gossip Infos Sent | per second | Number of sent gossip Info objects |
cockroachdb_intentage | Intentage | seconds | Cumulative age of intents |
cockroachdb_intentbytes | Intentbytes | bytes | Number of bytes in intent KV pairs |
cockroachdb_intentcount | Intentcount | Keys | Count of intent keys |
cockroachdb_keybytes | Keybytes | Bytes | Number of bytes taken up by keys |
cockroachdb_keycount | Keycount | Keys | Count of all keys |
cockroachdb_lastupdatenanos | Lastupdatenanos | nanoseconds | Time since the last update of Unix epoch at which bytes/keys/intents metrics |
cockroachdb_leases_epoch | Leases Epoch | Number of replica leaseholders using epoch-based leases | |
cockroachdb_leases_error | Leases Error | Requests / second | Number of failed lease requests |
cockroachdb_leases_expiration | Leases Expiration | Number of replica leaseholders using expiration-based leases | |
cockroachdb_leases_success | Leases Success | Requests / second | Number of successful lease requests |
cockroachdb_leases_transfers_error | Leases Transfers Error | per second | Number of failed lease transfers |
cockroachdb_leases_transfers_success | Leases Transfers Success | per second | Number of successful lease transfers |
cockroachdb_livebytes | Livebytes | bytes | Number of bytes of live data (keys plus values) |
cockroachdb_livecount | Livecount | Keys | Count of live keys |
cockroachdb_liveness_epochincrements | Liveness Epochincrements | per second | Number of times this node has incremented its liveness epoch |
cockroachdb_liveness_heartbeatfailures | Liveness Heartbeatfailures | per second | Number of failed node liveness heartbeats from this node |
cockroachdb_liveness_heartbeatlatency | Liveness Heartbeatlatency | nanoseconds | Average node liveness heartbeat latency since last pool |
cockroachdb_liveness_heartbeatsuccesses | Liveness Heartbeatsuccesses | per second | Number of successful node liveness heartbeats from this node |
cockroachdb_liveness_livenodes | Liveness Livenodes | Number of live nodes in the cluster (will be 0 if this node is not itself live) | |
cockroachdb_node_id | Node Id | Node ID with labels for advertised RPC and HTTP addresses | |
cockroachdb_queue_consistency_pending | Queue Consistency Pending | Number of pending replicas in the consistency checker queue | |
cockroachdb_queue_consistency_process_failure | Queue Consistency Process Failure | per second | Number of replicas that failed processing in the consistency checker queue |
cockroachdb_queue_consistency_process_success | Queue Consistency Process Success | per second | Number of replicas successfully processed by the consistency checker queue |
cockroachdb_queue_consistency_processingnanos | Queue Consistency Processingnanos | nanoseconds / second | nanoseconds spent to process replicas in the consistency checker queue |
cockroachdb_queue_gc_info_abortspanconsidered | Queue Gc Info Abortspanconsidered | per second | Number of AbortSpan entries old enough to be considered for removal |
cockroachdb_queue_gc_info_abortspangcnum | Queue Gc Info Abortspangcnum | per second | Number of AbortSpan entries fit for removal |
cockroachdb_queue_gc_info_abortspanscanned | Queue Gc Info Abortspanscanned | Transactions / second | Number of transactions present in the AbortSpan scanned from the engine |
cockroachdb_queue_gc_info_intentsconsidered | Queue Gc Info Intentsconsidered | per second | Number of 'old' intents |
cockroachdb_queue_gc_info_intenttxns | Queue Gc Info Intenttxns | Transactions / second | Number of associated distinct transactions |
cockroachdb_queue_gc_info_numkeysaffected | Queue Gc Info Numkeysaffected | Keys / second | Number of keys with GC'able data |
cockroachdb_queue_gc_info_pushtxn | Queue Gc Info Pushtxn | per second | Number of attempted pushes |
cockroachdb_queue_gc_info_resolvesuccess | Queue Gc Info Resolvesuccess | per second | Number of successful intent resolutions |
cockroachdb_queue_gc_info_resolvetotal | Queue Gc Info Resolvetotal | per second | Number of attempted intent resolutions |
cockroachdb_queue_gc_info_transactionspangcaborted | Queue Gc Info Transactionspangcaborted | per second | Number of GC'able entries corresponding to aborted transactions |
cockroachdb_queue_gc_info_transactionspangccommitted | Queue Gc Info Transactionspangccommitted | per second | Number of GC'able entries corresponding to committed transactions |
cockroachdb_queue_gc_info_transactionspangcpending | Queue Gc Info Transactionspangcpending | per second | Number of GC'able entries corresponding to pending transactions |
cockroachdb_queue_gc_info_transactionspanscanned | Queue Gc Info Transactionspanscanned | per second | Number of entries in transaction spans scanned from the engine |
cockroachdb_queue_gc_pending | Queue Gc Pending | Number of pending replicas in the GC queue | |
cockroachdb_queue_gc_process_failure | Queue Gc Process Failure | per second | Number of replicas that failed processing in the GC queue |
cockroachdb_queue_gc_process_success | Queue Gc Process Success | per second | Number of replicas successfully processed by the GC queue |
cockroachdb_queue_gc_processingnanos | Queue Gc Processingnanos | nanoseconds / second | Time spent to process replicas in the GC queue |
cockroachdb_queue_raftlog_pending | Queue Raftlog Pending | Number of pending replicas in the Raft log queue | |
cockroachdb_queue_raftlog_process_failure | Queue Raftlog Process Failure | per second | Number of replicas that failed processing in the Raft log queue |
cockroachdb_queue_raftlog_process_success | Queue Raftlog Process Success | per second | Number of replicas successfully processed by the Raft log queue |
cockroachdb_queue_raftlog_processingnanos | Queue Raftlog Processingnanos | nanoseconds / second | Time spent to process replicas in the Raft log queue |
cockroachdb_queue_raftsnapshot_pending | Queue Raftsnapshot Pending | Number of pending replicas in the Raft repair queue | |
cockroachdb_queue_raftsnapshot_process_failure | Queue Raftsnapshot Process Failure | per second | Number of replicas that failed processing in the Raft repair queue |
cockroachdb_queue_raftsnapshot_process_success | Queue Raftsnapshot Process Success | per second | Number of replicas successfully processed by the Raft repair queue |
cockroachdb_queue_raftsnapshot_processingnanos | Queue Raftsnapshot Processingnanos | nanoseconds / second | Time spent to process replicas in the Raft repair queue |
cockroachdb_queue_replicagc_pending | Queue Replicagc Pending | Number of pending replicas in the replica GC queue | |
cockroachdb_queue_replicagc_process_failure | Queue Replicagc Process Failure | per second | Number of replicas that failed processing in the replica GC queue |
cockroachdb_queue_replicagc_process_success | Queue Replicagc Process Success | per second | Number of replicas successfully processed by the replica GC queue |
cockroachdb_queue_replicagc_processingnanos | Queue Replicagc Processingnanos | nanoseconds / second | Time spent processing replicas in the replica GC queue |
cockroachdb_queue_replicagc_removereplica | Queue Replicagc Removereplica | per second | Number of replica removals attempted by the replica gc queue |
cockroachdb_queue_replicate_addreplica | Queue Replicate Addreplica | per second | Number of replica additions attempted by the replicate queue |
cockroachdb_queue_replicate_pending | Queue Replicate Pending | Number of pending replicas in the replicate queue | |
cockroachdb_queue_replicate_process_failure | Queue Replicate Process Failure | per second | Number of replicas that failed processing in the replicate queue |
cockroachdb_queue_replicate_process_success | Queue Replicate Process Success | per second | Number of replicas successfully processed by the replicate queue |
cockroachdb_queue_replicate_processingnanos | Queue Replicate Processingnanos | nanoseconds / second | Time spent to process replicas in the replicate queue |
cockroachdb_queue_replicate_purgatory | Queue Replicate Purgatory | Number of replicas in the replicate queue's purgatory, awaiting allocation options | |
cockroachdb_queue_replicate_rebalancereplica | Queue Replicate Rebalancereplica | per second | Number of replica rebalancer-initiated additions attempted by the replicate queue |
cockroachdb_queue_replicate_removedeadreplica | Queue Replicate Removedeadreplica | per second | Number of dead replica removals attempted by the replicate queue (typically in response to a node outage) |
cockroachdb_queue_replicate_removereplica | Queue Replicate Removereplica | per second | Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition) |
cockroachdb_queue_replicate_transferlease | Queue Replicate Transferlease | per second | Number of range lease transfers attempted by the replicate queue |
cockroachdb_queue_split_pending | Queue Split Pending | Number of pending replicas in the split queue | |
cockroachdb_queue_split_process_failure | Queue Split Process Failure | per second | Number of replicas that failed processing in the split queue |
cockroachdb_queue_split_process_success | Queue Split Process Success | per second | Number of replicas successfully processed by the split queue |
cockroachdb_queue_split_processingnanos | Queue Split Processingnanos | nanoseconds / second | Time spent to process replicas in the split queue |
cockroachdb_queue_tsmaintenance_pending | Queue Tsmaintenance Pending | Number of pending replicas in the time series maintenance queue | |
cockroachdb_queue_tsmaintenance_process_failure | Queue Tsmaintenance Process Failure | per second | Number of replicas that failed processing in the time series maintenance queue |
cockroachdb_queue_tsmaintenance_process_success | Queue Tsmaintenance Process Success | per second | Number of replicas successfully processed by the time series maintenance queue |
cockroachdb_queue_tsmaintenance_processingnanos | Queue Tsmaintenance Processingnanos | nanoseconds / second | Time spent to process replicas in the time series maintenance queue |
cockroachdb_raft_commandsapplied | Raft Commandsapplied | Commands / second | Count of Raft commands applied |
cockroachdb_raft_enqueued_pending | Raft Enqueued Pending | Number of pending outgoing messages in the Raft Transport queue | |
cockroachdb_raft_heartbeats_pending | Raft Heartbeats Pending | Number of pending heartbeats and responses waiting to be coalesced | |
cockroachdb_raft_process_commandcommit_latency | Raft Process Commandcommit Latency | nanoseconds | Average latency histogram for committing Raft commands since last pool |
cockroachdb_raft_process_logcommit_latency | Raft Process Logcommit Latency | nanoseconds | Average Latency histogram for committing Raft log entries since last pool |
cockroachdb_raft_process_tickingnanos | Raft Process Tickingnanos | nanoseconds / second | Time spent in store.processRaft() processing replica.Tick() |
cockroachdb_raft_process_workingnanos | Raft Process Workingnanos | nanoseconds / second | Time spent in store.processRaft() working |
cockroachdb_raft_rcvd_app | Raft Rcvd App | per second | Number of MsgApp messages received by this store |
cockroachdb_raft_rcvd_appresp | Raft Rcvd Appresp | per second | Number of MsgAppResp messages received by this store |
cockroachdb_raft_rcvd_dropped | Raft Rcvd Dropped | per second | Number of dropped incoming Raft messages |
cockroachdb_raft_rcvd_heartbeat | Raft Rcvd Heartbeat | per second | Number of (coalesced, if enabled) MsgHeartbeat messages received by this store |
cockroachdb_raft_rcvd_heartbeatresp | Raft Rcvd Heartbeatresp | per second | Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store |
cockroachdb_raft_rcvd_prevote | Raft Rcvd Prevote | per second | Number of MsgPreVote messages received by this store |
cockroachdb_raft_rcvd_prevoteresp | Raft Rcvd Prevoteresp | per second | Number of MsgPreVoteResp messages received by this store |
cockroachdb_raft_rcvd_prop | Raft Rcvd Prop | per second | Number of MsgProp messages received by this store |
cockroachdb_raft_rcvd_snap | Raft Rcvd Snap | per second | Number of MsgSnap messages received by this store |
cockroachdb_raft_rcvd_timeoutnow | Raft Rcvd Timeoutnow | per second | Number of MsgTimeoutNow messages received by this store |
cockroachdb_raft_rcvd_transferleader | Raft Rcvd Transferleader | per second | Number of MsgTransferLeader messages received by this store |
cockroachdb_raft_rcvd_vote | Raft Rcvd Vote | per second | Number of MsgVote messages received by this store |
cockroachdb_raft_rcvd_voteresp | Raft Rcvd Voteresp | per second | Number of MsgVoteResp messages received by this store |
cockroachdb_raft_ticks | Raft Ticks | per second | Number of Raft ticks queued |
cockroachdb_raftlog_behind | Raftlog Behind | Entries | Number of Raft log entries followers on other stores are behind |
cockroachdb_raftlog_truncated | Raftlog Truncated | Entries / second | Number of Raft log entries truncated |
cockroachdb_range_adds | Range Adds | per second | Number of range additions |
cockroachdb_range_raftleadertransfers | Range Raftleadertransfers | per second | Number of raft leader transfers |
cockroachdb_range_removes | Range Removes | per second | Number of range removals |
cockroachdb_range_snapshots_generated | Range Snapshots Generated | per second | Number of generated snapshots |
cockroachdb_range_snapshots_normal_applied | Range Snapshots Normal Applied | per second | Number of applied snapshots |
cockroachdb_range_snapshots_preemptive_applied | Range Snapshots Preemptive Applied | per second | Number of applied pre-emptive snapshots |
cockroachdb_range_splits_total | Range Splits Total | per second | Number of range splits |
cockroachdb_ranges | Ranges | Number of ranges | |
cockroachdb_ranges_unavailable | Ranges Unavailable | Number of ranges with fewer live replicas than needed for quorum | |
cockroachdb_ranges_underreplicated | Ranges Underreplicated | Number of ranges with fewer live replicas than the replication target | |
cockroachdb_rebalancing_writespersecond | Rebalancing Writespersecond | Keys | Number of keys written (applied by raft) per second to the store, averaged over a large time period as used in rebalancing decisions |
cockroachdb_replicas_commandqueue_combinedqueuesize | Replicas Commandqueue Combinedqueuesize | Commands | Number of commands in all CommandQueues combined |
cockroachdb_replicas_commandqueue_combinedreadcount | Replicas Commandqueue Combinedreadcount | Commands | Number of read-only commands in all CommandQueues combined |
cockroachdb_replicas_commandqueue_combinedwritecount | Replicas Commandqueue Combinedwritecount | Commands | Number of read-write commands in all CommandQueues combined |
cockroachdb_replicas_commandqueue_maxoverlaps | Replicas Commandqueue Maxoverlaps | Commands | Largest number of overlapping commands seen when adding to any CommandQueue |
cockroachdb_replicas_commandqueue_maxreadcount | Replicas Commandqueue Maxreadcount | Commands | Largest number of read-only commands in any CommandQueue |
cockroachdb_replicas_commandqueue_maxsize | Replicas Commandqueue Maxsize | Commands | Largest number of commands in any CommandQueue |
cockroachdb_replicas_commandqueue_maxtreesize | Replicas Commandqueue Maxtreesize | Largest number of intervals in any CommandQueue's interval tree | |
cockroachdb_replicas_commandqueue_maxwritecount | Replicas Commandqueue Maxwritecount | Commands | Largest number of read-write commands in any CommandQueue |
cockroachdb_replicas_leaders | Replicas Leaders | Number of raft leaders | |
cockroachdb_replicas_leaders_not_leaseholders | Replicas Leaders Not Leaseholders | Number of replicas that are Raft leaders whose range lease is held by another store | |
cockroachdb_replicas_leaseholders | Replicas Leaseholders | Number of lease holders | |
cockroachdb_replicas_quiescent | Replicas Quiescent | Number of quiesced replicas | |
cockroachdb_replicas_reserved | Replicas Reserved | Number of replicas reserved for snapshots | |
cockroachdb_replicas_total | Replicas Total | Number of replicas | |
cockroachdb_requests_backpressure_split | Requests Backpressure Split | Number of backpressured writes waiting on a Range split | |
cockroachdb_requests_slow_commandqueue | Requests Slow Commandqueue | Requests | Number of requests that have been stuck for a long time in the command queue |
cockroachdb_requests_slow_distsender | Requests Slow Distsender | Requests | Number of requests that have been stuck for a long time in the dist sender |
cockroachdb_requests_slow_lease | Requests Slow Lease | Requests | Number of requests that have been stuck for a long time acquiring a lease |
cockroachdb_requests_slow_raft | Requests Slow Raft | Requests | Number of requests that have been stuck for a long time in raft |
cockroachdb_rocksdb_block_cache_hits | Rocksdb Block Cache Hits | Count of block cache hits | |
cockroachdb_rocksdb_block_cache_misses | Rocksdb Block Cache Misses | Count of block cache misses | |
cockroachdb_rocksdb_block_cache_pinned_usage | Rocksdb Block Cache Pinned Usage | bytes | Bytes pinned by the block cache |
cockroachdb_rocksdb_block_cache_usage | Rocksdb Block Cache Usage | bytes | Bytes used by the block cache |
cockroachdb_rocksdb_bloom_filter_prefix_checked | Rocksdb Bloom Filter Prefix Checked | Number of times the bloom filter was checked | |
cockroachdb_rocksdb_bloom_filter_prefix_useful | Rocksdb Bloom Filter Prefix Useful | Number of times the bloom filter helped avoid iterator creation | |
cockroachdb_rocksdb_compactions_total | Rocksdb Compactions Total | Number of table compactions | |
cockroachdb_rocksdb_flushes_total | Rocksdb Flushes Total | Number of table flushes | |
cockroachdb_rocksdb_memtable_total_size | Rocksdb Memtable Total Size | bytes | Current size of memtable |
cockroachdb_rocksdb_num_sstables | Rocksdb Num Sstables | Tables | Number of rocksdb SSTables |
cockroachdb_rocksdb_read_amplification | Rocksdb Read Amplification | Reads | Number of disk reads per query |
cockroachdb_rocksdb_table_readers_mem_estimate | Rocksdb Table Readers Mem Estimate | Memory used by index and filter blocks | |
cockroachdb_round_trip_latency | Round Trip Latency | nanoseconds | Average distribution of round-trip latencies with other nodes since last pool |
cockroachdb_sql_bytesin | Sql Bytesin | bytes / second | Number of SQL bytes received |
cockroachdb_sql_bytesout | Sql Bytesout | bytes / second | Number of SQL bytes sent |
cockroachdb_sql_conns | Sql Conns | Connections | Number of active SQL connections |
cockroachdb_sql_ddl_count | Sql Ddl Count | per second | Number of SQL DDL statements |
cockroachdb_sql_delete_count | Sql Delete Count | per second | Number of SQL DELETE statements |
cockroachdb_sql_distsql_exec_latency | Sql Distsql Exec Latency | nanoseconds | Average Latency of DistSQL statement execution since last pool |
cockroachdb_sql_distsql_flows_active | Sql Distsql Flows Active | Number of distributed SQL flows currently active | |
cockroachdb_sql_distsql_flows_total | Sql Distsql Flows Total | per second | Number of distributed SQL flows executed |
cockroachdb_sql_distsql_queries_active | Sql Distsql Queries Active | Number of distributed SQL queries currently active | |
cockroachdb_sql_distsql_queries_total | Sql Distsql Queries Total | per second | Number of distributed SQL queries executed |
cockroachdb_sql_distsql_select_count | Sql Distsql Select Count | per second | Number of DistSQL SELECT statements |
cockroachdb_sql_distsql_service_latency | Sql Distsql Service Latency | nanoseconds | Average Latency of DistSQL request execution since last pool |
cockroachdb_sql_exec_latency | Sql Exec Latency | nanoseconds | Average Latency of SQL statement execution since last pool |
cockroachdb_sql_insert_count | Sql Insert Count | per second | Number of SQL INSERT statements |
cockroachdb_sql_mem_admin_current | Sql Mem Admin Current | Current SQL statement memory usage for admin | |
cockroachdb_sql_mem_admin_max | Sql Mem Admin Max | Average memory usage per SQL statement for admin since last pool | |
cockroachdb_sql_mem_admin_session_current | Sql Mem Admin Session Current | Current SQL session memory usage for admin | |
cockroachdb_sql_mem_admin_session_max | Sql Mem Admin Session Max | Average memory usage per SQL session for admin since last pool | |
cockroachdb_sql_mem_admin_txn_current | Sql Mem Admin Txn Current | Current SQL transaction memory usage for admin | |
cockroachdb_sql_mem_admin_txn_max | Sql Mem Admin Txn Max | Average memory usage per SQL transaction for admin since the last pool. | |
cockroachdb_sql_mem_client_current | Sql Mem Client Current | Current SQL statement memory usage for client | |
cockroachdb_sql_mem_client_max | Sql Mem Client Max | Average memory usage per SQL statement for client since the last pool. | |
cockroachdb_sql_mem_client_session_current | Sql Mem Client Session Current | Current SQL session memory usage for client | |
cockroachdb_sql_mem_client_session_max | Sql Mem Client Session Max | Average memory usage per SQL session for client since last pool. | |
cockroachdb_sql_mem_client_txn_current | Sql Mem Client Txn Current | Current SQL transaction memory usage for client | |
cockroachdb_sql_mem_client_txn_max | Sql Mem Client Txn Max | Average memory usage per SQL transaction for client since last pool. | |
cockroachdb_sql_mem_conns_current | Sql Mem Conns Current | Current SQL statement memory usage for conns | |
cockroachdb_sql_mem_conns_max | Sql Mem Conns Max | Average memory usage per SQL statement for conns since last pool. | |
cockroachdb_sql_mem_conns_session_current | Sql Mem Conns Session Current | Current SQL session memory usage for conns | |
cockroachdb_sql_mem_conns_session_max | Sql Mem Conns Session Max | Average memory usage per SQL session for conns since last pool. | |
cockroachdb_sql_mem_conns_txn_current | Sql Mem Conns Txn Current | Current SQL transaction memory usage for conns | |
cockroachdb_sql_mem_conns_txn_max | Sql Mem Conns Txn Max | Average memory usage per SQL transaction for conns since last pool. | |
cockroachdb_sql_mem_distsql_current | Sql Mem Distsql Current | Current SQL statement memory usage for distsql | |
cockroachdb_sql_mem_distsql_max | Sql Mem Distsql Max | Average memory usage per SQL statement for distsql since last pool. | |
cockroachdb_sql_mem_internal_current | Sql Mem Internal Current | Current sql statement memory usage for internal | |
cockroachdb_sql_mem_internal_max | Sql Mem Internal Max | Average memory usage per SQL statement for internal since last pool. | |
cockroachdb_sql_mem_internal_session_current | Sql Mem Internal Session Current | Current sql session memory usage for internal | |
cockroachdb_sql_mem_internal_session_max | Sql Mem Internal Session Max | Average memory usage per SQL session for internal since last pool. | |
cockroachdb_sql_mem_internal_txn_current | Sql Mem Internal Txn Current | Current sql transaction memory usage for internal | |
cockroachdb_sql_mem_internal_txn_max | Sql Mem Internal Txn Max | Average memory usage per SQL transaction for internal since last pool | |
cockroachdb_sql_misc_count | Sql Misc Count | per second | Number of other SQL statements |
cockroachdb_sql_query_count | Sql Query Count | per second | Number of SQL queries |
cockroachdb_sql_select_count | Sql Select Count | per second | Number of SQL SELECT statements |
cockroachdb_sql_service_latency | Sql Service Latency | nanoseconds | Average latency of SQL request execution since last pool |
cockroachdb_sql_txn_abort_count | Sql Txn Abort Count | per second | Number of SQL transaction ABORT statements |
cockroachdb_sql_txn_begin_count | Sql Txn Begin Count | per second | Number of SQL transaction BEGIN statements |
cockroachdb_sql_txn_commit_count | Sql Txn Commit Count | per second | Number of SQL transaction COMMIT statements |
cockroachdb_sql_txn_rollback_count | Sql Txn Rollback Count | per second | Number of SQL transaction ROLLBACK statements |
cockroachdb_sql_update_count | Sql Update Count | per second | Number of SQL UPDATE statements |
cockroachdb_sys_cgo_allocbytes | Sys Cgo Allocbytes | bytes | Current bytes of memory allocated by cgo |
cockroachdb_sys_cgo_totalbytes | Sys Cgo Totalbytes | bytes | Total bytes of memory allocated by cgo, but not released |
cockroachdb_sys_cgocalls | Sys Cgocalls | Total number of cgo calls | |
cockroachdb_sys_cpu_sys_ns | Sys Cpu Sys Ns | nanoseconds | Total system CPU time |
cockroachdb_sys_cpu_sys_percent | Sys Cpu Sys Percent | Current system CPU percentage | |
cockroachdb_sys_cpu_user_ns | Sys Cpu User Ns | nanoseconds | Total user CPU time |
cockroachdb_sys_cpu_user_percent | Sys Cpu User Percent | percent | Current user CPU percentage |
cockroachdb_sys_fd_open | Sys Fd Open | Process open file descriptors | |
cockroachdb_sys_fd_softlimit | Sys Fd Softlimit | Process open FD soft limit | |
cockroachdb_sys_gc_count | Sys Gc Count | Total number of GC runs | |
cockroachdb_sys_gc_pause_ns | Sys Gc Pause Ns | nanoseconds | Total GC pause |
cockroachdb_sys_gc_pause_percent | Sys Gc Pause Percent | percent | Current GC pause percentage |
cockroachdb_sys_go_allocbytes | Sys Go Allocbytes | bytes | Current bytes of memory allocated by go |
cockroachdb_sys_go_totalbytes | Sys Go Totalbytes | bytes | Total bytes of memory allocated by go, but not released |
cockroachdb_sys_goroutines | Sys Goroutines | Current number of goroutines | |
cockroachdb_sys_rss | Sys Rss | Current process RSS | |
cockroachdb_sys_uptime | Sys Uptime | seconds | Process uptime |
cockroachdb_sysbytes | Sysbytes | bytes | Number of bytes in system KV pairs |
cockroachdb_syscount | Syscount | Count of system KV pairs | |
cockroachdb_timeseries_write_bytes | Timeseries Write Bytes | bytes / second | Total size of metric samples written to disk |
cockroachdb_timeseries_write_errors | Timeseries Write Errors | Errors / second | Total errors encountered while attempting to write metrics to disk |
cockroachdb_timeseries_write_samples | Timeseries Write Samples | per second | Total number of metric samples written to disk |
cockroachdb_totalbytes | Totalbytes | Bytes | Total number of bytes taken up by keys and values including non-live data |
cockroachdb_tscache_skl_read_pages | Tscache Skl Read Pages | Number of pages in the read timestamp cache | |
cockroachdb_tscache_skl_read_rotations | Tscache Skl Read Rotations | per second | Number of page rotations in the read timestamp cache |
cockroachdb_tscache_skl_write_pages | Tscache Skl Write Pages | Number of pages in the write timestamp cache | |
cockroachdb_tscache_skl_write_rotations | Tscache Skl Write Rotations | per second | Number of page rotations in the write timestamp cache |
cockroachdb_txn_abandons | Txn Abandons | per second | Number of abandoned KV transactions |
cockroachdb_txn_aborts | Txn Aborts | per second | Number of aborted KV transactions |
cockroachdb_txn_autoretries | Txn Autoretries | per second | Number of automatic retries to avoid serializable restarts |
cockroachdb_txn_commits | Txn Commits | per second | Number of committed KV transactions (including 1PC) |
cockroachdb_txn_commits1PC | Txn Commits1Pc | per second | Number of committed one-phase KV transactions |
cockroachdb_txn_durations | Txn Durations | Average KV transaction durations since last pool. | |
cockroachdb_txn_restarts | Txn Restarts | Average Number of restarted KV transactions since last pool. | |
cockroachdb_txn_restarts_deleterange | Txn Restarts Deleterange | per second | Number of restarts due to a forwarded commit timestamp and a DeleteRange command |
cockroachdb_txn_restarts_possiblereplay | Txn Restarts Possiblereplay | per second | Number of restarts due to possible replays of command batches at the storage layer |
cockroachdb_txn_restarts_serializable | Txn Restarts Serializable | per second | Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE |
cockroachdb_txn_restarts_writetooold | Txn Restarts Writetooold | per second | Number of restarts due to a concurrent writer committing first |
cockroachdb_valbytes | Valbytes | bytes | Number of bytes taken up by values |
cockroachdb_valcount | Valcount | Count of all values |