The CockroachDB check monitors the overall health and performance of a CockroachDB cluster.
The CockroachDB check is included in the Datadog Agent package, so you do not need to install anything else on your server.
To configure this check for an Agent running on a host:
Edit the cockroachdb.d/conf.yaml
file, in the conf.d/
folder at the root of your Agent’s configuration directory to start collecting your CockroachDB performance data. See the sample cockroachdb.d/conf.yaml for all available configuration options.
For containerized environments, see the Autodiscovery Integration Templates for guidance on applying the parameters below.
Parameter | Value |
---|---|
<INTEGRATION_NAME> | cockroachdb |
<INIT_CONFIG> | blank or {} |
<INSTANCE_CONFIG> | {"prometheus_url":"http://%%host%%:8080/_status/vars"} |
Run the Agent’s status
subcommand and look for cockroachdb
under the Checks section.
cockroachdb.addsstable.applications (count) | Number of SSTable ingestions applied (i.e. applied by Replicas) Shown as operation |
cockroachdb.addsstable.copies (count) | number of SSTable ingestions that required copying files during application Shown as operation |
cockroachdb.addsstable.proposals (count) | Number of SSTable ingestions proposed (i.e. sent to Raft by lease holders) Shown as operation |
cockroachdb.build.timestamp (gauge) | Build information Shown as time |
cockroachdb.capacity.available (gauge) | Available storage capacity Shown as byte |
cockroachdb.capacity.reserved (gauge) | Capacity reserved for snapshots Shown as byte |
cockroachdb.capacity.total (gauge) | Total storage capacity Shown as byte |
cockroachdb.capacity.used (gauge) | Used storage capacity Shown as byte |
cockroachdb.clock.offset.meannanos (gauge) | Mean clock offset with other nodes in nanoseconds Shown as nanosecond |
cockroachdb.clock.offset.stddevnanos (gauge) | Stdddev clock offset with other nodes in nanoseconds Shown as nanosecond |
cockroachdb.compactor.compactingnanos (count) | Number of nanoseconds spent compacting ranges Shown as nanosecond |
cockroachdb.compactor.compactions.failure (count) | Number of failed compaction requests sent to the storage engine Shown as request |
cockroachdb.compactor.compactions.success (count) | Number of successful compaction requests sent to the storage engine Shown as request |
cockroachdb.compactor.suggestionbytes.compacted (count) | Number of logical bytes compacted from suggested compactions Shown as byte |
cockroachdb.compactor.suggestionbytes.queued (gauge) | Number of logical bytes in suggested compactions in the queue Shown as byte |
cockroachdb.compactor.suggestionbytes.skipped (count) | Number of logical bytes in suggested compactions which were not compacted Shown as byte |
cockroachdb.distsender.batches.partial (count) | Number of partial batches processed |
cockroachdb.distsender.batches.total (count) | Number of batches processed |
cockroachdb.distsender.errors.notleaseholder (count) | Number of NotLeaseHolderErrors encountered Shown as error |
cockroachdb.distsender.rpc.sent.local (count) | Number of local RPCs sent |
cockroachdb.distsender.rpc.sent.nextreplicaerror (count) | Number of RPCs sent due to per-replica errors Shown as error |
cockroachdb.distsender.rpc.sent.total (count) | Number of RPCs sent |
cockroachdb.exec.error (count) | Number of batch KV requests that failed to execute on this node Shown as request |
cockroachdb.exec.latency (gauge) | Latency in nanoseconds of batch KV requests executed on this node Shown as nanosecond |
cockroachdb.exec.success (count) | Number of batch KV requests executed successfully on this node Shown as request |
cockroachdb.gcbytesage (gauge) | Cumulative age of non-live data in seconds Shown as second |
cockroachdb.gossip.bytes.received (count) | Number of received gossip bytes Shown as byte |
cockroachdb.gossip.bytes.sent (count) | Number of sent gossip bytes Shown as byte |
cockroachdb.gossip.connections.incoming (gauge) | Number of active incoming gossip connections Shown as connection |
cockroachdb.gossip.connections.outgoing (gauge) | Number of active outgoing gossip connections Shown as connection |
cockroachdb.gossip.connections.refused (count) | Number of refused incoming gossip connections Shown as connection |
cockroachdb.gossip.infos.received (count) | Number of received gossip Info objects |
cockroachdb.gossip.infos.sent (count) | Number of sent gossip Info objects |
cockroachdb.intentage (gauge) | Cumulative age of intents in seconds Shown as second |
cockroachdb.intentbytes (gauge) | Number of bytes in intent KV pairs Shown as byte |
cockroachdb.intentcount (gauge) | Count of intent keys Shown as key |
cockroachdb.keybytes (gauge) | Number of bytes taken up by keys Shown as byte |
cockroachdb.keycount (gauge) | Count of all keys Shown as key |
cockroachdb.lastupdatenanos (gauge) | Time in nanoseconds since Unix epoch at which bytes/keys/intents metrics were last updated Shown as nanosecond |
cockroachdb.leases.epoch (gauge) | Number of replica leaseholders using epoch-based leases |
cockroachdb.leases.error (count) | Number of failed lease requests Shown as request |
cockroachdb.leases.expiration (gauge) | Number of replica leaseholders using expiration-based leases |
cockroachdb.leases.success (count) | Number of successful lease requests Shown as request |
cockroachdb.leases.transfers.error (count) | Number of failed lease transfers |
cockroachdb.leases.transfers.success (count) | Number of successful lease transfers |
cockroachdb.livebytes (gauge) | Number of bytes of live data (keys plus values) Shown as byte |
cockroachdb.livecount (gauge) | Count of live keys Shown as key |
cockroachdb.liveness.epochincrements (count) | Number of times this node has incremented its liveness epoch |
cockroachdb.liveness.heartbeatfailures (count) | Number of failed node liveness heartbeats from this node |
cockroachdb.liveness.heartbeatlatency (gauge) | Node liveness heartbeat latency in nanoseconds Shown as nanosecond |
cockroachdb.liveness.heartbeatsuccesses (count) | Number of successful node liveness heartbeats from this node |
cockroachdb.liveness.livenodes (gauge) | Number of live nodes in the cluster (will be 0 if this node is not itself live) |
cockroachdb.node_id (gauge) | node ID with labels for advertised RPC and HTTP addresses |
cockroachdb.queue.consistency.pending (gauge) | Number of pending replicas in the consistency checker queue |
cockroachdb.queue.consistency.process.failure (count) | Number of replicas which failed processing in the consistency checker queue |
cockroachdb.queue.consistency.process.success (count) | Number of replicas successfully processed by the consistency checker queue |
cockroachdb.queue.consistency.processingnanos (count) | Nanoseconds spent processing replicas in the consistency checker queue Shown as nanosecond |
cockroachdb.queue.gc.info.abortspanconsidered (count) | Number of AbortSpan entries old enough to be considered for removal |
cockroachdb.queue.gc.info.abortspangcnum (count) | Number of AbortSpan entries fit for removal |
cockroachdb.queue.gc.info.abortspanscanned (count) | Number of transactions present in the AbortSpan scanned from the engine Shown as transaction |
cockroachdb.queue.gc.info.intentsconsidered (count) | Number of 'old' intents |
cockroachdb.queue.gc.info.intenttxns (count) | Number of associated distinct transactions Shown as transaction |
cockroachdb.queue.gc.info.numkeysaffected (count) | Number of keys with GC'able data Shown as key |
cockroachdb.queue.gc.info.pushtxn (count) | Number of attempted pushes |
cockroachdb.queue.gc.info.resolvesuccess (count) | Number of successful intent resolutions |
cockroachdb.queue.gc.info.resolvetotal (count) | Number of attempted intent resolutions |
cockroachdb.queue.gc.info.transactionspangcaborted (count) | Number of GC'able entries corresponding to aborted txns |
cockroachdb.queue.gc.info.transactionspangccommitted (count) | Number of GC'able entries corresponding to committed txns |
cockroachdb.queue.gc.info.transactionspangcpending (count) | Number of GC'able entries corresponding to pending txns |
cockroachdb.queue.gc.info.transactionspanscanned (count) | Number of entries in transaction spans scanned from the engine |
cockroachdb.queue.gc.pending (gauge) | Number of pending replicas in the GC queue |
cockroachdb.queue.gc.process.failure (count) | Number of replicas which failed processing in the GC queue |
cockroachdb.queue.gc.process.success (count) | Number of replicas successfully processed by the GC queue |
cockroachdb.queue.gc.processingnanos (count) | Nanoseconds spent processing replicas in the GC queue Shown as nanosecond |
cockroachdb.queue.raftlog.pending (gauge) | Number of pending replicas in the Raft log queue |
cockroachdb.queue.raftlog.process.failure (count) | Number of replicas which failed processing in the Raft log queue |
cockroachdb.queue.raftlog.process.success (count) | Number of replicas successfully processed by the Raft log queue |
cockroachdb.queue.raftlog.processingnanos (count) | Nanoseconds spent processing replicas in the Raft log queue Shown as nanosecond |
cockroachdb.queue.raftsnapshot.pending (gauge) | Number of pending replicas in the Raft repair queue |
cockroachdb.queue.raftsnapshot.process.failure (count) | Number of replicas which failed processing in the Raft repair queue |
cockroachdb.queue.raftsnapshot.process.success (count) | Number of replicas successfully processed by the Raft repair queue |
cockroachdb.queue.raftsnapshot.processingnanos (count) | Nanoseconds spent processing replicas in the Raft repair queue Shown as nanosecond |
cockroachdb.queue.replicagc.pending (gauge) | Number of pending replicas in the replica GC queue |
cockroachdb.queue.replicagc.process.failure (count) | Number of replicas which failed processing in the replica GC queue |
cockroachdb.queue.replicagc.process.success (count) | Number of replicas successfully processed by the replica GC queue |
cockroachdb.queue.replicagc.processingnanos (count) | Nanoseconds spent processing replicas in the replica GC queue Shown as nanosecond |
cockroachdb.queue.replicagc.removereplica (count) | Number of replica removals attempted by the replica gc queue |
cockroachdb.queue.replicate.addreplica (count) | Number of replica additions attempted by the replicate queue |
cockroachdb.queue.replicate.pending (gauge) | Number of pending replicas in the replicate queue |
cockroachdb.queue.replicate.process.failure (count) | Number of replicas which failed processing in the replicate queue |
cockroachdb.queue.replicate.process.success (count) | Number of replicas successfully processed by the replicate queue |
cockroachdb.queue.replicate.processingnanos (count) | Nanoseconds spent processing replicas in the replicate queue Shown as nanosecond |
cockroachdb.queue.replicate.purgatory (gauge) | Number of replicas in the replicate queue's purgatory, awaiting allocation options |
cockroachdb.queue.replicate.rebalancereplica (count) | Number of replica rebalancer-initiated additions attempted by the replicate queue |
cockroachdb.queue.replicate.removedeadreplica (count) | Number of dead replica removals attempted by the replicate queue (typically in response to a node outage) |
cockroachdb.queue.replicate.removereplica (count) | Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition) |
cockroachdb.queue.replicate.transferlease (count) | Number of range lease transfers attempted by the replicate queue |
cockroachdb.queue.split.pending (gauge) | Number of pending replicas in the split queue |
cockroachdb.queue.split.process.failure (count) | Number of replicas which failed processing in the split queue |
cockroachdb.queue.split.process.success (count) | Number of replicas successfully processed by the split queue |
cockroachdb.queue.split.processingnanos (count) | Nanoseconds spent processing replicas in the split queue Shown as nanosecond |
cockroachdb.queue.tsmaintenance.pending (gauge) | Number of pending replicas in the time series maintenance queue |
cockroachdb.queue.tsmaintenance.process.failure (count) | Number of replicas which failed processing in the time series maintenance queue |
cockroachdb.queue.tsmaintenance.process.success (count) | Number of replicas successfully processed by the time series maintenance queue |
cockroachdb.queue.tsmaintenance.processingnanos (count) | Nanoseconds spent processing replicas in the time series maintenance queue Shown as nanosecond |
cockroachdb.raft.commandsapplied (count) | Count of Raft commands applied Shown as command |
cockroachdb.raft.enqueued.pending (gauge) | Number of pending outgoing messages in the Raft Transport queue |
cockroachdb.raft.heartbeats.pending (gauge) | Number of pending heartbeats and responses waiting to be coalesced |
cockroachdb.raft.process.commandcommit.latency (gauge) | Latency histogram in nanoseconds for committing Raft commands Shown as nanosecond |
cockroachdb.raft.process.logcommit.latency (gauge) | Latency histogram in nanoseconds for committing Raft log entries Shown as nanosecond |
cockroachdb.raft.process.tickingnanos (count) | Nanoseconds spent in store.processRaft() processing replica.Tick() Shown as nanosecond |
cockroachdb.raft.process.workingnanos (count) | Nanoseconds spent in store.processRaft() working Shown as nanosecond |
cockroachdb.raft.rcvd.app (count) | Number of MsgApp messages received by this store |
cockroachdb.raft.rcvd.appresp (count) | Number of MsgAppResp messages received by this store |
cockroachdb.raft.rcvd.dropped (count) | Number of dropped incoming Raft messages |
cockroachdb.raft.rcvd.heartbeat (count) | Number of (coalesced, if enabled) MsgHeartbeat messages received by this store |
cockroachdb.raft.rcvd.heartbeatresp (count) | Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store |
cockroachdb.raft.rcvd.prevote (count) | Number of MsgPreVote messages received by this store |
cockroachdb.raft.rcvd.prevoteresp (count) | Number of MsgPreVoteResp messages received by this store |
cockroachdb.raft.rcvd.prop (count) | Number of MsgProp messages received by this store |
cockroachdb.raft.rcvd.snap (count) | Number of MsgSnap messages received by this store |
cockroachdb.raft.rcvd.timeoutnow (count) | Number of MsgTimeoutNow messages received by this store |
cockroachdb.raft.rcvd.transferleader (count) | Number of MsgTransferLeader messages received by this store |
cockroachdb.raft.rcvd.vote (count) | Number of MsgVote messages received by this store |
cockroachdb.raft.rcvd.voteresp (count) | Number of MsgVoteResp messages received by this store |
cockroachdb.raft.ticks (count) | Number of Raft ticks queued |
cockroachdb.raftlog.behind (gauge) | Number of Raft log entries followers on other stores are behind Shown as entry |
cockroachdb.raftlog.truncated (count) | Number of Raft log entries truncated Shown as entry |
cockroachdb.range.adds (count) | Number of range additions |
cockroachdb.range.raftleadertransfers (count) | Number of raft leader transfers |
cockroachdb.range.removes (count) | Number of range removals |
cockroachdb.range.snapshots.generated (count) | Number of generated snapshots |
cockroachdb.range.snapshots.normal_applied (count) | Number of applied snapshots |
cockroachdb.range.snapshots.preemptive_applied (count) | Number of applied pre-emptive snapshots |
cockroachdb.range.splits.total (count) | Number of range splits |
cockroachdb.ranges (gauge) | Number of ranges |
cockroachdb.ranges.unavailable (gauge) | Number of ranges with fewer live replicas than needed for quorum |
cockroachdb.ranges.underreplicated (gauge) | Number of ranges with fewer live replicas than the replication target |
cockroachdb.rebalancing.writespersecond (gauge) | Number of keys written (i.e. applied by raft) per second to the store, averaged over a large time period as used in rebalancing decisions Shown as key |
cockroachdb.replicas.commandqueue.combinedqueuesize (gauge) | Number of commands in all CommandQueues combined Shown as command |
cockroachdb.replicas.commandqueue.combinedreadcount (gauge) | Number of read-only commands in all CommandQueues combined Shown as command |
cockroachdb.replicas.commandqueue.combinedwritecount (gauge) | Number of read-write commands in all CommandQueues combined Shown as command |
cockroachdb.replicas.commandqueue.maxoverlaps (gauge) | Largest number of overlapping commands seen when adding to any CommandQueue Shown as command |
cockroachdb.replicas.commandqueue.maxreadcount (gauge) | Largest number of read-only commands in any CommandQueue Shown as command |
cockroachdb.replicas.commandqueue.maxsize (gauge) | Largest number of commands in any CommandQueue Shown as command |
cockroachdb.replicas.commandqueue.maxtreesize (gauge) | Largest number of intervals in any CommandQueue's interval tree |
cockroachdb.replicas.commandqueue.maxwritecount (gauge) | Largest number of read-write commands in any CommandQueue Shown as command |
cockroachdb.replicas.leaders (gauge) | Number of raft leaders |
cockroachdb.replicas.leaders.not_leaseholders (gauge) | Number of replicas that are Raft leaders whose range lease is held by another store |
cockroachdb.replicas.leaseholders (gauge) | Number of lease holders |
cockroachdb.replicas.quiescent (gauge) | Number of quiesced replicas |
cockroachdb.replicas.reserved (gauge) | Number of replicas reserved for snapshots |
cockroachdb.replicas.total (gauge) | Number of replicas |
cockroachdb.requests.backpressure.split (gauge) | Number of backpressured writes waiting on a Range split |
cockroachdb.requests.slow.commandqueue (gauge) | Number of requests that have been stuck for a long time in the command queue Shown as request |
cockroachdb.requests.slow.distsender (gauge) | Number of requests that have been stuck for a long time in the dist sender Shown as request |
cockroachdb.requests.slow.lease (gauge) | Number of requests that have been stuck for a long time acquiring a lease Shown as request |
cockroachdb.requests.slow.raft (gauge) | Number of requests that have been stuck for a long time in raft Shown as request |
cockroachdb.rocksdb.block.cache.hits (gauge) | Count of block cache hits |
cockroachdb.rocksdb.block.cache.misses (gauge) | Count of block cache misses |
cockroachdb.rocksdb.block.cache.pinned.usage (gauge) | Bytes pinned by the block cache Shown as byte |
cockroachdb.rocksdb.block.cache.usage (gauge) | Bytes used by the block cache Shown as byte |
cockroachdb.rocksdb.bloom_filter.prefix.checked (gauge) | Number of times the bloom filter was checked |
cockroachdb.rocksdb.bloom_filter.prefix.useful (gauge) | Number of times the bloom filter helped avoid iterator creation |
cockroachdb.rocksdb.compactions.total (gauge) | Number of table compactions |
cockroachdb.rocksdb.flushes.total (gauge) | Number of table flushes |
cockroachdb.rocksdb.memtable.total.size (gauge) | Current size of memtable in bytes Shown as byte |
cockroachdb.rocksdb.num_sstables (gauge) | Number of rocksdb SSTables Shown as table |
cockroachdb.rocksdb.read.amplification (gauge) | Number of disk reads per query Shown as read |
cockroachdb.rocksdb.table.readers.mem.estimate (gauge) | Memory used by index and filter blocks |
cockroachdb.round_trip.latency (gauge) | Distribution of round-trip latencies with other nodes in nanoseconds Shown as nanosecond |
cockroachdb.sql.bytesin (count) | Number of sql bytes received Shown as byte |
cockroachdb.sql.bytesout (count) | Number of sql bytes sent Shown as byte |
cockroachdb.sql.conns (gauge) | Number of active sql connections Shown as connection |
cockroachdb.sql.ddl.count (count) | Number of SQL DDL statements |
cockroachdb.sql.delete.count (count) | Number of SQL DELETE statements |
cockroachdb.sql.distsql.exec.latency (gauge) | Latency in nanoseconds of DistSQL statement execution Shown as nanosecond |
cockroachdb.sql.distsql.flows.active (gauge) | Number of distributed SQL flows currently active |
cockroachdb.sql.distsql.flows.total (count) | Number of distributed SQL flows executed |
cockroachdb.sql.distsql.queries.active (gauge) | Number of distributed SQL queries currently active |
cockroachdb.sql.distsql.queries.total (count) | Number of distributed SQL queries executed |
cockroachdb.sql.distsql.select.count (count) | Number of DistSQL SELECT statements |
cockroachdb.sql.distsql.service.latency (gauge) | Latency in nanoseconds of DistSQL request execution Shown as nanosecond |
cockroachdb.sql.exec.latency (gauge) | Latency in nanoseconds of SQL statement execution Shown as nanosecond |
cockroachdb.sql.insert.count (count) | Number of SQL INSERT statements |
cockroachdb.sql.mem.admin.current (gauge) | Current sql statement memory usage for admin |
cockroachdb.sql.mem.admin.max (gauge) | Memory usage per sql statement for admin |
cockroachdb.sql.mem.admin.session.current (gauge) | Current sql session memory usage for admin |
cockroachdb.sql.mem.admin.session.max (gauge) | Memory usage per sql session for admin |
cockroachdb.sql.mem.admin.txn.current (gauge) | Current sql transaction memory usage for admin |
cockroachdb.sql.mem.admin.txn.max (gauge) | Memory usage per sql transaction for admin |
cockroachdb.sql.mem.client.current (gauge) | Current sql statement memory usage for client |
cockroachdb.sql.mem.client.max (gauge) | Memory usage per sql statement for client |
cockroachdb.sql.mem.client.session.current (gauge) | Current sql session memory usage for client |
cockroachdb.sql.mem.client.session.max (gauge) | Memory usage per sql session for client |
cockroachdb.sql.mem.client.txn.current (gauge) | Current sql transaction memory usage for client |
cockroachdb.sql.mem.client.txn.max (gauge) | Memory usage per sql transaction for client |
cockroachdb.sql.mem.conns.current (gauge) | Current sql statement memory usage for conns |
cockroachdb.sql.mem.conns.max (gauge) | Memory usage per sql statement for conns |
cockroachdb.sql.mem.conns.session.current (gauge) | Current sql session memory usage for conns |
cockroachdb.sql.mem.conns.session.max (gauge) | Memory usage per sql session for conns |
cockroachdb.sql.mem.conns.txn.current (gauge) | Current sql transaction memory usage for conns |
cockroachdb.sql.mem.conns.txn.max (gauge) | Memory usage per sql transaction for conns |
cockroachdb.sql.mem.distsql.current (gauge) | Current sql statement memory usage for distsql |
cockroachdb.sql.mem.distsql.max (gauge) | Memory usage per sql statement for distsql |
cockroachdb.sql.mem.internal.current (gauge) | Current sql statement memory usage for internal |
cockroachdb.sql.mem.internal.max (gauge) | Memory usage per sql statement for internal |
cockroachdb.sql.mem.internal.session.current (gauge) | Current sql session memory usage for internal |
cockroachdb.sql.mem.internal.session.max (gauge) | Memory usage per sql session for internal |
cockroachdb.sql.mem.internal.txn.current (gauge) | Current sql transaction memory usage for internal |
cockroachdb.sql.mem.internal.txn.max (gauge) | Memory usage per sql transaction for internal |
cockroachdb.sql.misc.count (count) | Number of other SQL statements |
cockroachdb.sql.query.count (count) | Number of SQL queries |
cockroachdb.sql.select.count (count) | Number of SQL SELECT statements |
cockroachdb.sql.service.latency (gauge) | Latency in nanoseconds of SQL request execution Shown as nanosecond |
cockroachdb.sql.txn.abort.count (count) | Number of SQL transaction ABORT statements |
cockroachdb.sql.txn.begin.count (count) | Number of SQL transaction BEGIN statements |
cockroachdb.sql.txn.commit.count (count) | Number of SQL transaction COMMIT statements |
cockroachdb.sql.txn.rollback.count (count) | Number of SQL transaction ROLLBACK statements |
cockroachdb.sql.update.count (count) | Number of SQL UPDATE statements |
cockroachdb.sys.cgo.allocbytes (gauge) | Current bytes of memory allocated by cgo Shown as byte |
cockroachdb.sys.cgo.totalbytes (gauge) | Total bytes of memory allocated by cgo, but not released Shown as byte |
cockroachdb.sys.cgocalls (gauge) | Total number of cgo calls |
cockroachdb.sys.cpu.sys.ns (gauge) | Total system cpu time in nanoseconds Shown as nanosecond |
cockroachdb.sys.cpu.sys.percent (gauge) | Current system cpu percentage |
cockroachdb.sys.cpu.user.ns (gauge) | Total user cpu time in nanoseconds Shown as nanosecond |
cockroachdb.sys.cpu.user.percent (gauge) | Current user cpu percentage Shown as percent |
cockroachdb.sys.fd.open (gauge) | Process open file descriptors |
cockroachdb.sys.fd.softlimit (gauge) | Process open FD soft limit |
cockroachdb.sys.gc.count (gauge) | Total number of GC runs |
cockroachdb.sys.gc.pause.ns (gauge) | Total GC pause in nanoseconds Shown as nanosecond |
cockroachdb.sys.gc.pause.percent (gauge) | Current GC pause percentage Shown as percent |
cockroachdb.sys.go.allocbytes (gauge) | Current bytes of memory allocated by go Shown as byte |
cockroachdb.sys.go.totalbytes (gauge) | Total bytes of memory allocated by go, but not released Shown as byte |
cockroachdb.sys.goroutines (gauge) | Current number of goroutines |
cockroachdb.sys.rss (gauge) | Current process RSS |
cockroachdb.sys.uptime (gauge) | Process uptime in seconds Shown as second |
cockroachdb.sysbytes (gauge) | Number of bytes in system KV pairs Shown as byte |
cockroachdb.syscount (gauge) | Count of system KV pairs |
cockroachdb.timeseries.write.bytes (count) | Total size in bytes of metric samples written to disk Shown as byte |
cockroachdb.timeseries.write.errors (count) | Total errors encountered while attempting to write metrics to disk Shown as error |
cockroachdb.timeseries.write.samples (count) | Total number of metric samples written to disk |
cockroachdb.totalbytes (gauge) | Total number of bytes taken up by keys and values including non-live data Shown as byte |
cockroachdb.tscache.skl.read.pages (gauge) | Number of pages in the read timestamp cache |
cockroachdb.tscache.skl.read.rotations (count) | Number of page rotations in the read timestamp cache |
cockroachdb.tscache.skl.write.pages (gauge) | Number of pages in the write timestamp cache |
cockroachdb.tscache.skl.write.rotations (count) | Number of page rotations in the write timestamp cache |
cockroachdb.txn.abandons (count) | Number of abandoned KV transactions |
cockroachdb.txn.aborts (count) | Number of aborted KV transactions |
cockroachdb.txn.autoretries (count) | Number of automatic retries to avoid serializable restarts |
cockroachdb.txn.commits (count) | Number of committed KV transactions (including 1PC) |
cockroachdb.txn.commits1PC (count) | Number of committed one-phase KV transactions |
cockroachdb.txn.durations (gauge) | KV transaction durations in nanoseconds |
cockroachdb.txn.restarts (gauge) | Number of restarted KV transactions |
cockroachdb.txn.restarts.deleterange (count) | Number of restarts due to a forwarded commit timestamp and a DeleteRange command |
cockroachdb.txn.restarts.possiblereplay (count) | Number of restarts due to possible replays of command batches at the storage layer |
cockroachdb.txn.restarts.serializable (count) | Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE |
cockroachdb.txn.restarts.writetooold (count) | Number of restarts due to a concurrent writer committing first |
cockroachdb.valbytes (gauge) | Number of bytes taken up by values Shown as byte |
cockroachdb.valcount (gauge) | Count of all values |
The CockroachDB check does not include any service checks.
The CockroachDB check does not include any events.
Need help? Contact Datadog support.
Additional helpful documentation, links, and articles: