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