CockroachDB

Supported OS Linux Mac OS Windows

Présentation

Le check CockroachDB surveille les performances et la santé globales d’un cluster CockroachDB .

Configuration

Installation

Le check CockroachDB est inclus avec le package de l’Agent Datadog  : vous n’avez donc rien d’autre à installer sur votre serveur.

Configuration

Host

Pour configurer ce check lorsque l’Agent est exécuté sur un host :

  1. Modifiez le fichier cockroachdb.d/conf.yaml dans le dossier conf.d/ à la racine du répertoire de configuration de votre Agent pour commencer à recueillir vos données de performance CockroachDB. Consultez le fichier d’exemple cockroachdb.d/conf.yaml pour découvrir toutes les options de configuration disponibles.

  2. Redémarrez l’Agent .

Environnement conteneurisé

Consultez la documentation relative aux modèles d’intégration Autodiscovery pour découvrir comment appliquer les paramètres ci-dessous à un environnement conteneurisé.

ParamètreValeur
<NOM_INTÉGRATION>cockroachdb
<CONFIG_INIT>vide ou {}
<CONFIG_INSTANCE>{"prometheus_url":"http://%%host%%:8080/_status/vars"}

Validation

Lancez la sous-commande status de l’Agent et cherchez cockroachdb dans la section Checks.

Données collectées

Métriques

cockroachdb.addsstable.applications
(count)
[OpenMetrics v1] Number of SSTable ingestions applied (i.e. applied by Replicas)
Shown as operation
cockroachdb.addsstable.applications.count
(count)
[OpenMetrics v2] Number of SSTable ingestions applied (i.e. applied by Replicas)
Shown as operation
cockroachdb.addsstable.copies
(count)
[OpenMetrics v1] number of SSTable ingestions that required copying files during application
Shown as operation
cockroachdb.addsstable.copies.count
(count)
[OpenMetrics v2] number of SSTable ingestions that required copying files during application
Shown as operation
cockroachdb.addsstable.proposals
(count)
[OpenMetrics v1] Number of SSTable ingestions proposed (i.e. sent to Raft by lease holders)
Shown as operation
cockroachdb.addsstable.proposals.count
(count)
[OpenMetrics v2] Number of SSTable ingestions proposed (i.e. sent to Raft by lease holders)
Shown as operation
cockroachdb.build.timestamp
(gauge)
[OpenMetrics v1 & v2] Build information
Shown as time
cockroachdb.capacity.available
(gauge)
[OpenMetrics v1 & v2] Available storage capacity
Shown as byte
cockroachdb.capacity.reserved
(gauge)
[OpenMetrics v1 & v2] Capacity reserved for snapshots
Shown as byte
cockroachdb.capacity.total
(gauge)
[OpenMetrics v1 & v2] Total storage capacity
Shown as byte
cockroachdb.capacity.used
(gauge)
[OpenMetrics v1 & v2] Used storage capacity
Shown as byte
cockroachdb.clock.offset.meannanos
(gauge)
[OpenMetrics v1 & v2] Mean clock offset with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.clock.offset.stddevnanos
(gauge)
[OpenMetrics v1 & v2] Stdddev clock offset with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.compactor.compactingnanos
(count)
[OpenMetrics v1] Number of nanoseconds spent compacting ranges
Shown as nanosecond
cockroachdb.compactor.compactingnanos.count
(count)
[OpenMetrics v2] Number of nanoseconds spent compacting ranges
Shown as nanosecond
cockroachdb.compactor.compactions.failure
(count)
[OpenMetrics v1] Number of failed compaction requests sent to the storage engine
Shown as request
cockroachdb.compactor.compactions.failure.count
(count)
[OpenMetrics v2] Number of failed compaction requests sent to the storage engine
Shown as request
cockroachdb.compactor.compactions.success
(count)
[OpenMetrics v1] Number of successful compaction requests sent to the storage engine
Shown as request
cockroachdb.compactor.compactions.success.count
(count)
[OpenMetrics v2] Number of successful compaction requests sent to the storage engine
Shown as request
cockroachdb.compactor.suggestionbytes.compacted
(count)
[OpenMetrics v1] Number of logical bytes compacted from suggested compactions
Shown as byte
cockroachdb.compactor.suggestionbytes.compacted.count
(count)
[OpenMetrics v2] Number of logical bytes compacted from suggested compactions
Shown as byte
cockroachdb.compactor.suggestionbytes.queued
(gauge)
[OpenMetrics v1 & v2] Number of logical bytes in suggested compactions in the queue
Shown as byte
cockroachdb.compactor.suggestionbytes.skipped
(count)
[OpenMetrics v1] Number of logical bytes in suggested compactions which were not compacted
Shown as byte
cockroachdb.compactor.suggestionbytes.skipped.count
(count)
[OpenMetrics v2] Number of logical bytes in suggested compactions which were not compacted
Shown as byte
cockroachdb.distsender.batches.partial
(count)
[OpenMetrics v1] Number of partial batches processed
cockroachdb.distsender.batches.partial.count
(count)
[OpenMetrics v2] Number of partial batches processed
cockroachdb.distsender.batches.total.count
(count)
[OpenMetrics v2] Number of batches processed
cockroachdb.distsender.batches.total
(count)
[OpenMetrics v1] Number of batches processed
cockroachdb.distsender.errors.notleaseholder
(count)
[OpenMetrics v1] Number of NotLeaseHolderErrors encountered
Shown as error
cockroachdb.distsender.errors.notleaseholder.count
(count)
[OpenMetrics v2] Number of NotLeaseHolderErrors encountered
Shown as error
cockroachdb.distsender.rpc.sent.local
(count)
[OpenMetrics v1] Number of local RPCs sent
cockroachdb.distsender.rpc.sent.local.count
(count)
[OpenMetrics v2] Number of local RPCs sent
cockroachdb.distsender.rpc.sent.nextreplicaerror
(count)
[OpenMetrics v1] Number of RPCs sent due to per-replica errors
Shown as error
cockroachdb.distsender.rpc.sent.nextreplicaerror.count
(count)
[OpenMetrics v2] Number of RPCs sent due to per-replica errors
Shown as error
cockroachdb.distsender.rpc.sent.total
(count)
[OpenMetrics v1] Number of RPCs sent
cockroachdb.distsender.rpc.sent.total.count
(count)
[OpenMetrics v2] Number of replica-addressed RPCs sent
cockroachdb.exec.error
(count)
[OpenMetrics v1] Number of batch KV requests that failed to execute on this node. These are warnings denoting cleanup rather than errors, and can be disregarded as part of operation.
Shown as request
cockroachdb.exec.error.count
(count)
[OpenMetrics v2] Number of batch KV requests that failed to execute on this node. These are warnings denoting cleanup rather than errors, and can be disregarded as part of operation.
Shown as request
cockroachdb.exec.latency
(gauge)
[OpenMetrics v1] Latency in nanoseconds of batch KV requests executed on this node
Shown as nanosecond
cockroachdb.exec.latency.bucket
(count)
[OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node
Shown as nanosecond
cockroachdb.exec.latency.count
(count)
[OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node
Shown as nanosecond
cockroachdb.exec.latency.sum
(count)
[OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node
Shown as nanosecond
cockroachdb.exec.success
(count)
[OpenMetrics v1] Number of batch KV requests executed successfully on this node
Shown as request
cockroachdb.exec.success.count
(count)
[OpenMetrics v2] Number of batch KV requests executed successfully on this node
Shown as request
cockroachdb.gcbytesage
(gauge)
[OpenMetrics v1 & v2] Cumulative age of non-live data in seconds
Shown as second
cockroachdb.gossip.bytes.received
(count)
[OpenMetrics v1] Number of received gossip bytes
Shown as byte
cockroachdb.gossip.bytes.received.count
(count)
[OpenMetrics v2] Number of received gossip bytes
Shown as byte
cockroachdb.gossip.bytes.sent
(count)
[OpenMetrics v1] Number of sent gossip bytes
Shown as byte
cockroachdb.gossip.bytes.sent.count
(count)
[OpenMetrics v2] Number of sent gossip bytes
Shown as byte
cockroachdb.gossip.connections.incoming
(gauge)
[OpenMetrics v1 & v2] Number of active incoming gossip connections
Shown as connection
cockroachdb.gossip.connections.outgoing
(gauge)
[OpenMetrics v1 & v2] Number of active outgoing gossip connections
Shown as connection
cockroachdb.gossip.connections.refused
(count)
[OpenMetrics v1] Number of refused incoming gossip connections
Shown as connection
cockroachdb.gossip.connections.refused.count
(count)
[OpenMetrics v2] Number of refused incoming gossip connections
Shown as connection
cockroachdb.gossip.infos.received
(count)
[OpenMetrics v1] Number of received gossip Info objects
cockroachdb.gossip.infos.received.count
(count)
[OpenMetrics v2] Number of received gossip Info objects
cockroachdb.gossip.infos.sent
(count)
[OpenMetrics v1] Number of sent gossip Info objects
cockroachdb.gossip.infos.sent.count
(count)
[OpenMetrics v2] Number of sent gossip Info objects
cockroachdb.intentage
(gauge)
[OpenMetrics v1 & v2] Cumulative age of intents in seconds
Shown as second
cockroachdb.intentbytes
(gauge)
[OpenMetrics v1 & v2] Number of bytes in intent KV pairs
Shown as byte
cockroachdb.intentcount
(gauge)
[OpenMetrics v1 & v2] Count of intent keys
Shown as key
cockroachdb.keybytes
(gauge)
[OpenMetrics v1 & v2] Number of bytes taken up by keys
Shown as byte
cockroachdb.keycount
(gauge)
[OpenMetrics v1 & v2] Count of all keys
Shown as key
cockroachdb.lastupdatenanos
(gauge)
[OpenMetrics v1 & v2] Time in nanoseconds since Unix epoch at which bytes/keys/intents metrics were last updated
Shown as nanosecond
cockroachdb.leases.epoch
(gauge)
[OpenMetrics v1 & v2] Number of replica leaseholders using epoch-based leases
cockroachdb.leases.error
(count)
[OpenMetrics v1] Number of failed lease requests
Shown as request
cockroachdb.leases.error.count
(count)
[OpenMetrics v2] Number of failed lease requests
Shown as request
cockroachdb.leases.expiration
(gauge)
[OpenMetrics v1 & v2] Number of replica leaseholders using expiration-based leases
cockroachdb.leases.success
(count)
[OpenMetrics v1] Number of successful lease requests
Shown as request
cockroachdb.leases.success.count
(count)
[OpenMetrics v2] Number of successful lease requests
Shown as request
cockroachdb.leases.transfers.error
(count)
[OpenMetrics v1] Number of failed lease transfers
cockroachdb.leases.transfers.error.count
(count)
[OpenMetrics v2] Number of failed lease transfers
cockroachdb.leases.transfers.success
(count)
[OpenMetrics v1] Number of successful lease transfers
cockroachdb.leases.transfers.success.count
(count)
[OpenMetrics v2] Number of successful lease transfers
cockroachdb.livebytes
(gauge)
[OpenMetrics v1 & v2] Number of bytes of live data (keys plus values)
Shown as byte
cockroachdb.livecount
(gauge)
[OpenMetrics v1 & v2] Count of live keys
Shown as key
cockroachdb.liveness.epochincrements
(count)
[OpenMetrics v1] Number of times this node has incremented its liveness epoch
cockroachdb.liveness.epochincrements.count
(count)
[OpenMetrics v2] Number of times this node has incremented its liveness epoch
cockroachdb.liveness.heartbeatfailures
(count)
[OpenMetrics v1] Number of failed node liveness heartbeats from this node
cockroachdb.liveness.heartbeatfailures.count
(count)
[OpenMetrics v2] Number of failed node liveness heartbeats from this node
cockroachdb.liveness.heartbeatlatency
(gauge)
[OpenMetrics v1] Node liveness heartbeat latency in nanoseconds
Shown as nanosecond
cockroachdb.liveness.heartbeatlatency.bucket
(count)
[OpenMetrics v2] Node liveness heartbeat latency in nanoseconds
Shown as nanosecond
cockroachdb.liveness.heartbeatlatency.count
(count)
[OpenMetrics v2] Node liveness heartbeat latency in nanoseconds
Shown as nanosecond
cockroachdb.liveness.heartbeatlatency.sum
(count)
[OpenMetrics v2] Node liveness heartbeat latency in nanoseconds
Shown as nanosecond
cockroachdb.liveness.heartbeatsuccesses
(count)
[OpenMetrics v1] Number of successful node liveness heartbeats from this node
cockroachdb.liveness.heartbeatsuccesses.count
(count)
[OpenMetrics v2] Number of successful node liveness heartbeats from this node
cockroachdb.liveness.livenodes
(gauge)
[OpenMetrics v1 & v2] Number of live nodes in the cluster (will be 0 if this node is not itself live)
cockroachdb.node_id
(gauge)
[OpenMetrics v1 & v2] node ID with labels for advertised RPC and HTTP addresses
cockroachdb.queue.consistency.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the consistency checker queue
cockroachdb.queue.consistency.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the consistency checker queue
cockroachdb.queue.consistency.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the consistency checker queue
cockroachdb.queue.consistency.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the consistency checker queue
cockroachdb.queue.consistency.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the consistency checker queue
cockroachdb.queue.consistency.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the consistency checker queue
Shown as nanosecond
cockroachdb.queue.consistency.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the consistency checker queue
Shown as nanosecond
cockroachdb.queue.gc.info.abortspanconsidered
(count)
[OpenMetrics v1] Number of AbortSpan entries old enough to be considered for removal
cockroachdb.queue.gc.info.abortspanconsidered.count
(count)
[OpenMetrics v2] Number of AbortSpan entries old enough to be considered for removal
cockroachdb.queue.gc.info.abortspangcnum
(count)
[OpenMetrics v1] Number of AbortSpan entries fit for removal
cockroachdb.queue.gc.info.abortspangcnum.count
(count)
[OpenMetrics v2] Number of AbortSpan entries fit for removal
cockroachdb.queue.gc.info.abortspanscanned
(count)
[OpenMetrics v1] Number of transactions present in the AbortSpan scanned from the engine
Shown as transaction
cockroachdb.queue.gc.info.abortspanscanned.count
(count)
[OpenMetrics v2] Number of transactions present in the AbortSpan scanned from the engine
Shown as transaction
cockroachdb.queue.gc.info.intentsconsidered
(count)
[OpenMetrics v1] Number of 'old' intents
cockroachdb.queue.gc.info.intentsconsidered.count
(count)
[OpenMetrics v2] Number of 'old' intents
cockroachdb.queue.gc.info.intenttxns
(count)
[OpenMetrics v1] Number of associated distinct transactions
Shown as transaction
cockroachdb.queue.gc.info.intenttxns.count
(count)
[OpenMetrics v2] Number of associated distinct transactions
Shown as transaction
cockroachdb.queue.gc.info.numkeysaffected
(count)
[OpenMetrics v1] Number of keys with GC'able data
Shown as key
cockroachdb.queue.gc.info.numkeysaffected.count
(count)
[OpenMetrics v2] Number of keys with GC'able data
Shown as key
cockroachdb.queue.gc.info.pushtxn
(count)
[OpenMetrics v1] Number of attempted pushes
cockroachdb.queue.gc.info.pushtxn.count
(count)
[OpenMetrics v2] Number of attempted pushes
cockroachdb.queue.gc.info.resolvesuccess
(count)
[OpenMetrics v1] Number of successful intent resolutions
cockroachdb.queue.gc.info.resolvesuccess.count
(count)
[OpenMetrics v2] Number of successful intent resolutions
cockroachdb.queue.gc.info.resolvetotal
(count)
[OpenMetrics v1] Number of attempted intent resolutions
cockroachdb.queue.gc.info.resolvetotal.count
(count)
[OpenMetrics v2] Number of attempted intent resolutions
cockroachdb.queue.gc.info.transactionspangcaborted
(count)
[OpenMetrics v1] Number of GC'able entries corresponding to aborted txns
cockroachdb.queue.gc.info.transactionspangcaborted.count
(count)
[OpenMetrics v2] Number of GC'able entries corresponding to aborted txns
cockroachdb.queue.gc.info.transactionspangccommitted
(count)
[OpenMetrics v1] Number of GC'able entries corresponding to committed txns
cockroachdb.queue.gc.info.transactionspangccommitted.count
(count)
[OpenMetrics v2] Number of GC'able entries corresponding to committed txns
cockroachdb.queue.gc.info.transactionspangcpending
(count)
[OpenMetrics v1] Number of GC'able entries corresponding to pending txns
cockroachdb.queue.gc.info.transactionspangcpending.count
(count)
[OpenMetrics v2] Number of GC'able entries corresponding to pending txns
cockroachdb.queue.gc.info.transactionspanscanned
(count)
[OpenMetrics v1] Number of entries in transaction spans scanned from the engine
cockroachdb.queue.gc.info.transactionspanscanned.count
(count)
[OpenMetrics v2] Number of entries in transaction spans scanned from the engine
cockroachdb.queue.gc.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the GC queue
cockroachdb.queue.gc.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the GC queue
cockroachdb.queue.gc.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the GC queue
cockroachdb.queue.gc.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the GC queue
cockroachdb.queue.gc.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the GC queue
cockroachdb.queue.gc.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the GC queue
Shown as nanosecond
cockroachdb.queue.gc.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the GC queue
Shown as nanosecond
cockroachdb.queue.raftlog.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the Raft log queue
cockroachdb.queue.raftlog.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the Raft log queue
cockroachdb.queue.raftlog.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the Raft log queue
cockroachdb.queue.raftlog.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the Raft log queue
cockroachdb.queue.raftlog.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the Raft log queue
cockroachdb.queue.raftlog.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the Raft log queue
Shown as nanosecond
cockroachdb.queue.raftlog.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the Raft log queue
Shown as nanosecond
cockroachdb.queue.raftsnapshot.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the Raft repair queue
cockroachdb.queue.raftsnapshot.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the Raft repair queue
cockroachdb.queue.raftsnapshot.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the Raft repair queue
cockroachdb.queue.raftsnapshot.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the Raft repair queue
cockroachdb.queue.raftsnapshot.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the Raft repair queue
cockroachdb.queue.raftsnapshot.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the Raft repair queue
Shown as nanosecond
cockroachdb.queue.raftsnapshot.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the Raft repair queue
Shown as nanosecond
cockroachdb.queue.replicagc.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the replica GC queue
cockroachdb.queue.replicagc.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the replica GC queue
cockroachdb.queue.replicagc.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the replica GC queue
cockroachdb.queue.replicagc.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the replica GC queue
cockroachdb.queue.replicagc.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the replica GC queue
cockroachdb.queue.replicagc.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the replica GC queue
Shown as nanosecond
cockroachdb.queue.replicagc.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the replica GC queue
Shown as nanosecond
cockroachdb.queue.replicagc.removereplica
(count)
[OpenMetrics v1] Number of replica removals attempted by the replica gc queue
cockroachdb.queue.replicagc.removereplica.count
(count)
[OpenMetrics v2] Number of replica removals attempted by the replica gc queue
cockroachdb.queue.replicate.addreplica
(count)
[OpenMetrics v1] Number of replica additions attempted by the replicate queue
cockroachdb.queue.replicate.addreplica.count
(count)
[OpenMetrics v2] Number of replica additions attempted by the replicate queue
cockroachdb.queue.replicate.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the replicate queue
cockroachdb.queue.replicate.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the replicate queue
cockroachdb.queue.replicate.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the replicate queue
cockroachdb.queue.replicate.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the replicate queue
cockroachdb.queue.replicate.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the replicate queue
cockroachdb.queue.replicate.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the replicate queue
Shown as nanosecond
cockroachdb.queue.replicate.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the replicate queue
Shown as nanosecond
cockroachdb.queue.replicate.purgatory
(gauge)
[OpenMetrics v1 & v2] Number of replicas in the replicate queue's purgatory, awaiting allocation options
cockroachdb.queue.replicate.rebalancereplica
(count)
[OpenMetrics v1] Number of replica rebalancer-initiated additions attempted by the replicate queue
cockroachdb.queue.replicate.rebalancereplica.count
(count)
[OpenMetrics v2] Number of replica rebalancer-initiated additions attempted by the replicate queue
cockroachdb.queue.replicate.removedeadreplica
(count)
[OpenMetrics v1] Number of dead replica removals attempted by the replicate queue (typically in response to a node outage)
cockroachdb.queue.replicate.removedeadreplica.count
(count)
[OpenMetrics v2] Number of dead replica removals attempted by the replicate queue (typically in response to a node outage)
cockroachdb.queue.replicate.removereplica
(count)
[OpenMetrics v1] Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition)
cockroachdb.queue.replicate.removereplica.count
(count)
[OpenMetrics v2] Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition)
cockroachdb.queue.replicate.transferlease
(count)
[OpenMetrics v1] Number of range lease transfers attempted by the replicate queue
cockroachdb.queue.replicate.transferlease.count
(count)
[OpenMetrics v2] Number of range lease transfers attempted by the replicate queue
cockroachdb.queue.split.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the split queue
cockroachdb.queue.split.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the split queue
cockroachdb.queue.split.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the split queue
cockroachdb.queue.split.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the split queue
cockroachdb.queue.split.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the split queue
cockroachdb.queue.split.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the split queue
Shown as nanosecond
cockroachdb.queue.split.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the split queue
Shown as nanosecond
cockroachdb.queue.tsmaintenance.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending replicas in the time series maintenance queue
cockroachdb.queue.tsmaintenance.process.failure
(count)
[OpenMetrics v1] Number of replicas which failed processing in the time series maintenance queue
cockroachdb.queue.tsmaintenance.process.failure.count
(count)
[OpenMetrics v2] Number of replicas which failed processing in the time series maintenance queue
cockroachdb.queue.tsmaintenance.process.success
(count)
[OpenMetrics v1] Number of replicas successfully processed by the time series maintenance queue
cockroachdb.queue.tsmaintenance.process.success.count
(count)
[OpenMetrics v2] Number of replicas successfully processed by the time series maintenance queue
cockroachdb.queue.tsmaintenance.processingnanos
(count)
[OpenMetrics v1] Nanoseconds spent processing replicas in the time series maintenance queue
Shown as nanosecond
cockroachdb.queue.tsmaintenance.processingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent processing replicas in the time series maintenance queue
Shown as nanosecond
cockroachdb.raft.commandsapplied
(count)
[OpenMetrics v1] Count of Raft commands applied
Shown as command
cockroachdb.raft.commandsapplied.count
(count)
[OpenMetrics v2] Count of Raft commands applied
Shown as command
cockroachdb.raft.enqueued.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending outgoing messages in the Raft Transport queue
cockroachdb.raft.heartbeats.pending
(gauge)
[OpenMetrics v1 & v2] Number of pending heartbeats and responses waiting to be coalesced
cockroachdb.raft.process.commandcommit.latency
(gauge)
[OpenMetrics v1] Latency histogram in nanoseconds for committing Raft commands
Shown as nanosecond
cockroachdb.raft.process.commandcommit.latency.bucket
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands
Shown as nanosecond
cockroachdb.raft.process.commandcommit.latency.count
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands
Shown as nanosecond
cockroachdb.raft.process.commandcommit.latency.sum
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands
Shown as nanosecond
cockroachdb.raft.process.logcommit.latency
(gauge)
[OpenMetrics v1] Latency histogram in nanoseconds for committing Raft log entries
Shown as nanosecond
cockroachdb.raft.process.logcommit.latency.bucket
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries
Shown as nanosecond
cockroachdb.raft.process.logcommit.latency.count
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries
Shown as nanosecond
cockroachdb.raft.process.logcommit.latency.sum
(count)
[OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries
Shown as nanosecond
cockroachdb.raft.process.tickingnanos
(count)
[OpenMetrics v1] Nanoseconds spent in store.processRaft() processing replica.Tick()
Shown as nanosecond
cockroachdb.raft.process.tickingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent in store.processRaft() processing replica.Tick()
Shown as nanosecond
cockroachdb.raft.process.workingnanos
(count)
[OpenMetrics v1] Nanoseconds spent in store.processRaft() working
Shown as nanosecond
cockroachdb.raft.process.workingnanos.count
(count)
[OpenMetrics v2] Nanoseconds spent in store.processRaft() working
Shown as nanosecond
cockroachdb.raft.rcvd.app
(count)
[OpenMetrics v1] Number of MsgApp messages received by this store
cockroachdb.raft.rcvd.app.count
(count)
[OpenMetrics v2] Number of MsgApp messages received by this store
cockroachdb.raft.rcvd.appresp
(count)
[OpenMetrics v1] Number of MsgAppResp messages received by this store
cockroachdb.raft.rcvd.appresp.count
(count)
[OpenMetrics v2] Number of MsgAppResp messages received by this store
cockroachdb.raft.rcvd.dropped
(count)
[OpenMetrics v1] Number of dropped incoming Raft messages
cockroachdb.raft.rcvd.dropped.count
(count)
[OpenMetrics v2] Number of dropped incoming Raft messages
cockroachdb.raft.rcvd.heartbeat
(count)
[OpenMetrics v1] Number of (coalesced, if enabled) MsgHeartbeat messages received by this store
cockroachdb.raft.rcvd.heartbeat.count
(count)
[OpenMetrics v2] Number of (coalesced, if enabled) MsgHeartbeat messages received by this store
cockroachdb.raft.rcvd.heartbeatresp
(count)
[OpenMetrics v1] Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store
cockroachdb.raft.rcvd.heartbeatresp.count
(count)
[OpenMetrics v2] Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store
cockroachdb.raft.rcvd.prevote
(count)
[OpenMetrics v1] Number of MsgPreVote messages received by this store
cockroachdb.raft.rcvd.prevote.count
(count)
[OpenMetrics v2] Number of MsgPreVote messages received by this store
cockroachdb.raft.rcvd.prevoteresp
(count)
[OpenMetrics v1] Number of MsgPreVoteResp messages received by this store
cockroachdb.raft.rcvd.prevoteresp.count
(count)
[OpenMetrics v2] Number of MsgPreVoteResp messages received by this store
cockroachdb.raft.rcvd.prop
(count)
[OpenMetrics v1] Number of MsgProp messages received by this store
cockroachdb.raft.rcvd.prop.count
(count)
[OpenMetrics v2] Number of MsgProp messages received by this store
cockroachdb.raft.rcvd.snap
(count)
[OpenMetrics v1] Number of MsgSnap messages received by this store
cockroachdb.raft.rcvd.snap.count
(count)
[OpenMetrics v2] Number of MsgSnap messages received by this store
cockroachdb.raft.rcvd.timeoutnow
(count)
[OpenMetrics v1] Number of MsgTimeoutNow messages received by this store
cockroachdb.raft.rcvd.timeoutnow.count
(count)
[OpenMetrics v2] Number of MsgTimeoutNow messages received by this store
cockroachdb.raft.rcvd.transferleader
(count)
[OpenMetrics v1] Number of MsgTransferLeader messages received by this store
cockroachdb.raft.rcvd.transferleader.count
(count)
[OpenMetrics v2] Number of MsgTransferLeader messages received by this store
cockroachdb.raft.rcvd.vote
(count)
[OpenMetrics v1] Number of MsgVote messages received by this store
cockroachdb.raft.rcvd.vote.count
(count)
[OpenMetrics v2] Number of MsgVote messages received by this store
cockroachdb.raft.rcvd.voteresp
(count)
[OpenMetrics v1] Number of MsgVoteResp messages received by this store
cockroachdb.raft.rcvd.voteresp.count
(count)
[OpenMetrics v2] Number of MsgVoteResp messages received by this store
cockroachdb.raft.ticks
(count)
[OpenMetrics v1] Number of Raft ticks queued
cockroachdb.raft.ticks.count
(count)
[OpenMetrics v2] Number of Raft ticks queued
cockroachdb.raftlog.behind
(gauge)
[OpenMetrics v1 & v2] Number of Raft log entries followers on other stores are behind
Shown as entry
cockroachdb.raftlog.truncated
(count)
[OpenMetrics v1] Number of Raft log entries truncated
Shown as entry
cockroachdb.raftlog.truncated.count
(count)
[OpenMetrics v2] Number of Raft log entries truncated
Shown as entry
cockroachdb.range.adds
(count)
[OpenMetrics v1] Number of range additions
cockroachdb.range.adds.count
(count)
[OpenMetrics v2] Number of range additions
cockroachdb.range.raftleadertransfers
(count)
[OpenMetrics v1] Number of raft leader transfers
cockroachdb.range.raftleadertransfers.count
(count)
[OpenMetrics v2] Number of raft leader transfers
cockroachdb.range.removes
(count)
[OpenMetrics v1] Number of range removals
cockroachdb.range.removes.count
(count)
[OpenMetrics v2] Number of range removals
cockroachdb.range.snapshots.generated
(count)
[OpenMetrics v1] Number of generated snapshots
cockroachdb.range.snapshots.generated.count
(count)
[OpenMetrics v2] Number of generated snapshots
cockroachdb.range.snapshots.normal_applied
(count)
[OpenMetrics v1] Number of applied snapshots
cockroachdb.range.snapshots.normal_applied.count
(count)
[OpenMetrics v2] Number of applied snapshots
cockroachdb.range.snapshots.preemptive_applied
(count)
[OpenMetrics v1] Number of applied pre-emptive snapshots
cockroachdb.range.snapshots.preemptive_applied.count
(count)
[OpenMetrics v2] Number of applied pre-emptive snapshots
cockroachdb.range.splits.total
(count)
[OpenMetrics v1] Number of range splits
cockroachdb.range.splits.total.count
(count)
[OpenMetrics v2] Number of range splits
cockroachdb.ranges
(gauge)
[OpenMetrics v1 & v2] Number of ranges
cockroachdb.ranges.unavailable
(gauge)
[OpenMetrics v1 & v2] Number of ranges with fewer live replicas than needed for quorum
cockroachdb.ranges.underreplicated
(gauge)
[OpenMetrics v1 & v2] Number of ranges with fewer live replicas than the replication target
cockroachdb.rebalancing.writespersecond
(gauge)
[OpenMetrics v1 & v2] 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)
[OpenMetrics v1 & v2] Number of commands in all CommandQueues combined
Shown as command
cockroachdb.replicas.commandqueue.combinedreadcount
(gauge)
[OpenMetrics v1 & v2] Number of read-only commands in all CommandQueues combined
Shown as command
cockroachdb.replicas.commandqueue.combinedwritecount
(gauge)
[OpenMetrics v1 & v2] Number of read-write commands in all CommandQueues combined
Shown as command
cockroachdb.replicas.commandqueue.maxoverlaps
(gauge)
[OpenMetrics v1 & v2] Largest number of overlapping commands seen when adding to any CommandQueue
Shown as command
cockroachdb.replicas.commandqueue.maxreadcount
(gauge)
[OpenMetrics v1 & v2] Largest number of read-only commands in any CommandQueue
Shown as command
cockroachdb.replicas.commandqueue.maxsize
(gauge)
[OpenMetrics v1 & v2] Largest number of commands in any CommandQueue
Shown as command
cockroachdb.replicas.commandqueue.maxtreesize
(gauge)
[OpenMetrics v1 & v2] Largest number of intervals in any CommandQueue's interval tree
cockroachdb.replicas.commandqueue.maxwritecount
(gauge)
[OpenMetrics v1 & v2] Largest number of read-write commands in any CommandQueue
Shown as command
cockroachdb.replicas.leaders
(gauge)
[OpenMetrics v1 & v2] Number of raft leaders
cockroachdb.replicas.leaders.not_leaseholders
(gauge)
[OpenMetrics v1 & v2] Number of replicas that are Raft leaders whose range lease is held by another store
cockroachdb.replicas.leaseholders
(gauge)
[OpenMetrics v1 & v2] Number of lease holders
cockroachdb.replicas.quiescent
(gauge)
[OpenMetrics v1 & v2] Number of quiesced replicas
cockroachdb.replicas.reserved
(gauge)
[OpenMetrics v1 & v2] Number of replicas reserved for snapshots
cockroachdb.replicas.total
(gauge)
[OpenMetrics v1 & v2] Number of replicas
cockroachdb.requests.backpressure.split
(gauge)
[OpenMetrics v1 & v2] Number of backpressured writes waiting on a Range split
cockroachdb.requests.slow.commandqueue
(gauge)
[OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in the command queue
Shown as request
cockroachdb.requests.slow.distsender
(gauge)
[OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in the dist sender
Shown as request
cockroachdb.requests.slow.lease
(gauge)
[OpenMetrics v1 & v2] Number of requests that have been stuck for a long time acquiring a lease
Shown as request
cockroachdb.requests.slow.raft
(gauge)
[OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in raft
Shown as request
cockroachdb.rocksdb.block.cache.hits
(gauge)
[OpenMetrics v1 & v2] Count of block cache hits
cockroachdb.rocksdb.block.cache.misses
(gauge)
[OpenMetrics v1 & v2] Count of block cache misses
cockroachdb.rocksdb.block.cache.pinned.usage
(gauge)
[OpenMetrics v1 & v2] Bytes pinned by the block cache
Shown as byte
cockroachdb.rocksdb.block.cache.usage
(gauge)
[OpenMetrics v1 & v2] Bytes used by the block cache
Shown as byte
cockroachdb.rocksdb.bloom_filter.prefix.checked
(gauge)
[OpenMetrics v1 & v2] Number of times the bloom filter was checked
cockroachdb.rocksdb.bloom_filter.prefix.useful
(gauge)
[OpenMetrics v1 & v2] Number of times the bloom filter helped avoid iterator creation
cockroachdb.rocksdb.compactions.total
(gauge)
[OpenMetrics v1 & v2] Number of table compactions
cockroachdb.rocksdb.flushes.total
(gauge)
[OpenMetrics v1 & v2] Number of table flushes
cockroachdb.rocksdb.memtable.total.size
(gauge)
[OpenMetrics v1 & v2] Current size of memtable in bytes
Shown as byte
cockroachdb.rocksdb.num_sstables
(gauge)
[OpenMetrics v1 & v2] Number of rocksdb SSTables
Shown as table
cockroachdb.rocksdb.read.amplification
(gauge)
[OpenMetrics v1 & v2] Number of disk reads per query
Shown as read
cockroachdb.rocksdb.table.readers.mem.estimate
(gauge)
[OpenMetrics v1 & v2] Memory used by index and filter blocks
cockroachdb.round_trip.latency
(gauge)
[OpenMetrics v1] Distribution of round-trip latencies with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.round_trip.latency.bucket
(count)
[OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.round_trip.latency.count
(count)
[OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.round_trip.latency.sum
(count)
[OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds
Shown as nanosecond
cockroachdb.schedules.backup.failed
(count)
[OpenMetrics v1] Number of scheduled backup jobs failed
cockroachdb.schedules.backup.failed.count
(count)
[OpenMetrics v2] Number of scheduled backup jobs failed
cockroachdb.schedules.backup.started
(count)
[OpenMetrics v1] Number of scheduled backup jobs started
cockroachdb.schedules.backup.started.count
(count)
[OpenMetrics v2] Number of scheduled backup jobs started
cockroachdb.schedules.backup.succeeded
(count)
[OpenMetrics v1] Number of scheduled backup jobs succeeded
cockroachdb.schedules.backup.succeeded.count
(count)
[OpenMetrics v2] Number of scheduled backup jobs succeeded
cockroachdb.sql.bytesin
(count)
[OpenMetrics v1] Number of sql bytes received
Shown as byte
cockroachdb.sql.bytesin.count
(count)
[OpenMetrics v2] Number of sql bytes received
Shown as byte
cockroachdb.sql.bytesout
(count)
[OpenMetrics v1] Number of sql bytes sent
Shown as byte
cockroachdb.sql.bytesout.count
(count)
[OpenMetrics v2] Number of sql bytes sent
Shown as byte
cockroachdb.sql.conns
(gauge)
[OpenMetrics v1 & v2] Number of active sql connections
Shown as connection
cockroachdb.sql.ddl.count
(count)
[OpenMetrics v1 & v2] Number of SQL DDL statements
cockroachdb.sql.delete.count
(count)
[OpenMetrics v1 & v2] Number of SQL DELETE statements
cockroachdb.sql.distsql.exec.latency
(gauge)
[OpenMetrics v1] Latency in nanoseconds of DistSQL statement execution
Shown as nanosecond
cockroachdb.sql.distsql.exec.latency.bucket
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL statement execution
Shown as nanosecond
cockroachdb.sql.distsql.exec.latency.count
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL statement execution
Shown as nanosecond
cockroachdb.sql.distsql.exec.latency.sum
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL statement execution
Shown as nanosecond
cockroachdb.sql.distsql.flows.active
(gauge)
[OpenMetrics v1 & v2] Number of distributed SQL flows currently active
cockroachdb.sql.distsql.flows.count
(count)
[OpenMetrics v2] Number of distributed SQL flows executed
cockroachdb.sql.distsql.flows.total
(count)
[OpenMetrics v1] Number of distributed SQL flows executed
cockroachdb.sql.distsql.queries.active
(gauge)
[OpenMetrics v1 & v2] Number of distributed SQL queries currently active
cockroachdb.sql.distsql.queries.count
(count)
[OpenMetrics v2] Number of distributed SQL queries executed
cockroachdb.sql.distsql.queries.total
(count)
[OpenMetrics v1] Number of distributed SQL queries executed
cockroachdb.sql.distsql.select.count
(count)
[OpenMetrics v1 & v2] Number of DistSQL SELECT statements
cockroachdb.sql.distsql.service.latency
(gauge)
[OpenMetrics v1] Latency in nanoseconds of DistSQL request execution
Shown as nanosecond
cockroachdb.sql.distsql.service.latency.bucket
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL request execution
Shown as nanosecond
cockroachdb.sql.distsql.service.latency.count
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL request execution
Shown as nanosecond
cockroachdb.sql.distsql.service.latency.sum
(count)
[OpenMetrics v2] Latency in nanoseconds of DistSQL request execution
Shown as nanosecond
cockroachdb.sql.exec.latency
(gauge)
[OpenMetrics v1] Latency in nanoseconds of SQL statement execution
Shown as nanosecond
cockroachdb.sql.exec.latency.bucket
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL statement execution
Shown as nanosecond
cockroachdb.sql.exec.latency.count
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL statement execution
Shown as nanosecond
cockroachdb.sql.exec.latency.sum
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL statement execution
Shown as nanosecond
cockroachdb.sql.insert.count
(count)
[OpenMetrics v1 & v2] Number of SQL INSERT statements
cockroachdb.sql.mem.admin.current
(gauge)
[OpenMetrics v1 & v2] Current sql statement memory usage for admin
cockroachdb.sql.mem.admin.max
(gauge)
[OpenMetrics v1] Memory usage per sql statement for admin
cockroachdb.sql.mem.admin.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql statement for admin
cockroachdb.sql.mem.admin.max.count
(count)
[OpenMetrics v2] Memory usage per sql statement for admin
cockroachdb.sql.mem.admin.max.sum
(count)
[OpenMetrics v2] Memory usage per sql statement for admin
cockroachdb.sql.mem.admin.session.current
(gauge)
[OpenMetrics v1 & v2] Current sql session memory usage for admin
cockroachdb.sql.mem.admin.session.max
(gauge)
[OpenMetrics v1] Memory usage per sql session for admin
cockroachdb.sql.mem.admin.session.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql session for admin
cockroachdb.sql.mem.admin.session.max.count
(count)
[OpenMetrics v2] Memory usage per sql session for admin
cockroachdb.sql.mem.admin.session.max.sum
(count)
[OpenMetrics v2] Memory usage per sql session for admin
cockroachdb.sql.mem.admin.txn.current
(gauge)
[OpenMetrics v1 & v2] Current sql transaction memory usage for admin
cockroachdb.sql.mem.admin.txn.max
(gauge)
[OpenMetrics v1] Memory usage per sql transaction for admin
cockroachdb.sql.mem.admin.txn.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql transaction for admin
cockroachdb.sql.mem.admin.txn.max.count
(count)
[OpenMetrics v2] Memory usage per sql transaction for admin
cockroachdb.sql.mem.admin.txn.max.sum
(count)
[OpenMetrics v2] Memory usage per sql transaction for admin
cockroachdb.sql.mem.client.current
(gauge)
[OpenMetrics v1 & v2] Current sql statement memory usage for client
cockroachdb.sql.mem.client.max
(gauge)
[OpenMetrics v1] Memory usage per sql statement for client
cockroachdb.sql.mem.client.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql statement for client
cockroachdb.sql.mem.client.max.count
(count)
[OpenMetrics v2] Memory usage per sql statement for client
cockroachdb.sql.mem.client.max.sum
(count)
[OpenMetrics v2] Memory usage per sql statement for client
cockroachdb.sql.mem.client.session.current
(gauge)
[OpenMetrics v1 & v2] Current sql session memory usage for client
cockroachdb.sql.mem.client.session.max
(gauge)
[OpenMetrics v1] Memory usage per sql session for client
cockroachdb.sql.mem.client.session.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql session for client
cockroachdb.sql.mem.client.session.max.count
(count)
[OpenMetrics v2] Memory usage per sql session for client
cockroachdb.sql.mem.client.session.max.sum
(count)
[OpenMetrics v2] Memory usage per sql session for client
cockroachdb.sql.mem.client.txn.current
(gauge)
[OpenMetrics v1 & v2] Current sql transaction memory usage for client
cockroachdb.sql.mem.client.txn.max
(gauge)
[OpenMetrics v1] Memory usage per sql transaction for client
cockroachdb.sql.mem.client.txn.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql transaction for client
cockroachdb.sql.mem.client.txn.max.count
(count)
[OpenMetrics v2] Memory usage per sql transaction for client
cockroachdb.sql.mem.client.txn.max.sum
(count)
[OpenMetrics v2] Memory usage per sql transaction for client
cockroachdb.sql.mem.conns.current
(gauge)
[OpenMetrics v1 & v2] Current sql statement memory usage for conns
cockroachdb.sql.mem.conns.max
(gauge)
[OpenMetrics v1] Memory usage per sql statement for conns
cockroachdb.sql.mem.conns.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql statement for conns
cockroachdb.sql.mem.conns.max.count
(count)
[OpenMetrics v2] Memory usage per sql statement for conns
cockroachdb.sql.mem.conns.max.sum
(count)
[OpenMetrics v2] Memory usage per sql statement for conns
cockroachdb.sql.mem.conns.session.current
(gauge)
[OpenMetrics v1 & v2] Current sql session memory usage for conns
cockroachdb.sql.mem.conns.session.max
(gauge)
[OpenMetrics v1] Memory usage per sql session for conns
cockroachdb.sql.mem.conns.session.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql session for conns
cockroachdb.sql.mem.conns.session.max.count
(count)
[OpenMetrics v2] Memory usage per sql session for conns
cockroachdb.sql.mem.conns.session.max.sum
(count)
[OpenMetrics v2] Memory usage per sql session for conns
cockroachdb.sql.mem.conns.txn.current
(gauge)
[OpenMetrics v1 & v2] Current sql transaction memory usage for conns
cockroachdb.sql.mem.conns.txn.max
(gauge)
[OpenMetrics v1] Memory usage per sql transaction for conns
cockroachdb.sql.mem.conns.txn.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql transaction for conns
cockroachdb.sql.mem.conns.txn.max.count
(count)
[OpenMetrics v2] Memory usage per sql transaction for conns
cockroachdb.sql.mem.conns.txn.max.sum
(count)
[OpenMetrics v2] Memory usage per sql transaction for conns
cockroachdb.sql.mem.distsql.current
(gauge)
[OpenMetrics v1 & v2] Current sql statement memory usage for distsql
cockroachdb.sql.mem.distsql.max
(gauge)
[OpenMetrics v1] Memory usage per sql statement for distsql
cockroachdb.sql.mem.distsql.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql statement for distsql
cockroachdb.sql.mem.distsql.max.count
(count)
[OpenMetrics v2] Memory usage per sql statement for distsql
cockroachdb.sql.mem.distsql.max.sum
(count)
[OpenMetrics v2] Memory usage per sql statement for distsql
cockroachdb.sql.mem.internal.current
(gauge)
[OpenMetrics v1 & v2] Current sql statement memory usage for internal
cockroachdb.sql.mem.internal.max
(gauge)
[OpenMetrics v1] Memory usage per sql statement for internal
cockroachdb.sql.mem.internal.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql statement for internal
cockroachdb.sql.mem.internal.max.count
(count)
[OpenMetrics v2] Memory usage per sql statement for internal
cockroachdb.sql.mem.internal.max.sum
(count)
[OpenMetrics v2] Memory usage per sql statement for internal
cockroachdb.sql.mem.internal.session.current
(gauge)
[OpenMetrics v1 & v2] Current sql session memory usage for internal
cockroachdb.sql.mem.internal.session.max
(gauge)
[OpenMetrics v1] Memory usage per sql session for internal
cockroachdb.sql.mem.internal.session.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql session for internal
cockroachdb.sql.mem.internal.session.max.count
(count)
[OpenMetrics v2] Memory usage per sql session for internal
cockroachdb.sql.mem.internal.session.max.sum
(count)
[OpenMetrics v2] Memory usage per sql session for internal
cockroachdb.sql.mem.internal.txn.current
(gauge)
[OpenMetrics v1 & v2] Current sql transaction memory usage for internal
cockroachdb.sql.mem.internal.txn.max
(gauge)
[OpenMetrics v1] Memory usage per sql transaction for internal
cockroachdb.sql.mem.internal.txn.max.bucket
(count)
[OpenMetrics v2] Memory usage per sql transaction for internal
cockroachdb.sql.mem.internal.txn.max.count
(count)
[OpenMetrics v2] Memory usage per sql transaction for internal
cockroachdb.sql.mem.internal.txn.max.sum
(count)
[OpenMetrics v2] Memory usage per sql transaction for internal
cockroachdb.sql.misc.count
(count)
[OpenMetrics v1 & v2] Number of other SQL statements
cockroachdb.sql.query.count
(count)
[OpenMetrics v1 & v2] Number of SQL queries
cockroachdb.sql.select.count
(count)
[OpenMetrics v1 & v2] Number of SQL SELECT statements
cockroachdb.sql.service.latency
(gauge)
[OpenMetrics v1] Latency in nanoseconds of SQL request execution
Shown as nanosecond
cockroachdb.sql.service.latency.bucket
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL request execution
Shown as nanosecond
cockroachdb.sql.service.latency.count
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL request execution
Shown as nanosecond
cockroachdb.sql.service.latency.sum
(count)
[OpenMetrics v2] Latency in nanoseconds of SQL request execution
Shown as nanosecond
cockroachdb.sql.txn.abort.count
(count)
[OpenMetrics v1 & v2] Number of SQL transaction ABORT statements
cockroachdb.sql.txn.begin.count
(count)
[OpenMetrics v1 & v2] Number of SQL transaction BEGIN statements
cockroachdb.sql.txn.commit.count
(count)
[OpenMetrics v1 & v2] Number of SQL transaction COMMIT statements
cockroachdb.sql.txn.rollback.count
(count)
[OpenMetrics v1 & v2] Number of SQL transaction ROLLBACK statements
cockroachdb.sql.update.count
(count)
[OpenMetrics v1 & v2] Number of SQL UPDATE statements
cockroachdb.sys.cgo.allocbytes
(gauge)
[OpenMetrics v1 & v2] Current bytes of memory allocated by cgo
Shown as byte
cockroachdb.sys.cgo.totalbytes
(gauge)
[OpenMetrics v1 & v2] Total bytes of memory allocated by cgo, but not released
Shown as byte
cockroachdb.sys.cgocalls
(gauge)
[OpenMetrics v1 & v2] Total number of cgo calls
cockroachdb.sys.cpu.sys.ns
(gauge)
[OpenMetrics v1 & v2] Total system cpu time in nanoseconds
Shown as nanosecond
cockroachdb.sys.cpu.sys.percent
(gauge)
[OpenMetrics v1 & v2] Current system cpu percentage
Shown as core
cockroachdb.sys.cpu.user.ns
(gauge)
[OpenMetrics v1 & v2] Total user cpu time in nanoseconds
Shown as nanosecond
cockroachdb.sys.cpu.user.percent
(gauge)
[OpenMetrics v1 & v2] Current user cpu percentage
Shown as core
cockroachdb.sys.fd.open
(gauge)
[OpenMetrics v1 & v2] Process open file descriptors
cockroachdb.sys.fd.softlimit
(gauge)
[OpenMetrics v1 & v2] Process open FD soft limit
cockroachdb.sys.gc
(gauge)
[OpenMetrics v2] Total number of GC runs
cockroachdb.sys.gc.count
(gauge)
[OpenMetrics v1] Total number of GC runs
cockroachdb.sys.gc.pause.ns
(gauge)
[OpenMetrics v1 & v2] Total GC pause in nanoseconds
Shown as nanosecond
cockroachdb.sys.gc.pause.percent
(gauge)
[OpenMetrics v1 & v2] Current GC pause percentage
Shown as fraction
cockroachdb.sys.go.allocbytes
(gauge)
[OpenMetrics v1 & v2] Current bytes of memory allocated by go
Shown as byte
cockroachdb.sys.go.totalbytes
(gauge)
[OpenMetrics v1 & v2] Total bytes of memory allocated by go, but not released
Shown as byte
cockroachdb.sys.goroutines
(gauge)
[OpenMetrics v1 & v2] Current number of goroutines
cockroachdb.sys.rss
(gauge)
[OpenMetrics v1 & v2] Current process RSS
cockroachdb.sys.uptime
(gauge)
[OpenMetrics v1 & v2] Process uptime in seconds
Shown as second
cockroachdb.sysbytes
(gauge)
[OpenMetrics v1 & v2] Number of bytes in system KV pairs
Shown as byte
cockroachdb.syscount
(gauge)
[OpenMetrics v1 & v2] Count of system KV pairs
cockroachdb.timeseries.write.bytes
(count)
[OpenMetrics v1] Total size in bytes of metric samples written to disk
Shown as byte
cockroachdb.timeseries.write.bytes.count
(count)
[OpenMetrics v2] Total size in bytes of metric samples written to disk
Shown as byte
cockroachdb.timeseries.write.errors
(count)
[OpenMetrics v1] Total errors encountered while attempting to write metrics to disk
Shown as error
cockroachdb.timeseries.write.errors.count
(count)
[OpenMetrics v2] Total errors encountered while attempting to write metrics to disk
Shown as error
cockroachdb.timeseries.write.samples
(count)
[OpenMetrics v1] Total number of metric samples written to disk
cockroachdb.timeseries.write.samples.count
(count)
[OpenMetrics v2] Total number of metric samples written to disk
cockroachdb.totalbytes
(gauge)
[OpenMetrics v1 & v2] Total number of bytes taken up by keys and values including non-live data
Shown as byte
cockroachdb.tscache.skl.read.pages
(gauge)
[OpenMetrics v1 & v2] Number of pages in the read timestamp cache
cockroachdb.tscache.skl.read.rotations
(count)
[OpenMetrics v1] Number of page rotations in the read timestamp cache
cockroachdb.tscache.skl.read.rotations.count
(count)
[OpenMetrics v2] Number of page rotations in the read timestamp cache
cockroachdb.tscache.skl.write.pages
(gauge)
[OpenMetrics v1 & v2] Number of pages in the write timestamp cache
cockroachdb.tscache.skl.write.rotations
(count)
[OpenMetrics v1] Number of page rotations in the write timestamp cache
cockroachdb.tscache.skl.write.rotations.count
(count)
[OpenMetrics v2] Number of page rotations in the write timestamp cache
cockroachdb.txn.abandons
(count)
[OpenMetrics v1] Number of abandoned KV transactions
cockroachdb.txn.abandons.count
(count)
[OpenMetrics v2] Number of abandoned KV transactions
cockroachdb.txn.aborts
(count)
[OpenMetrics v1] Number of aborted KV transactions
cockroachdb.txn.aborts.count
(count)
[OpenMetrics v2] Number of aborted KV transactions
cockroachdb.txn.autoretries
(count)
[OpenMetrics v1] Number of automatic retries to avoid serializable restarts
cockroachdb.txn.autoretries.count
(count)
[OpenMetrics v2] Number of automatic retries to avoid serializable restarts
cockroachdb.txn.commits
(count)
[OpenMetrics v1] Number of committed KV transactions (including 1PC)
cockroachdb.txn.commits.count
(count)
[OpenMetrics v2] Number of committed KV transactions (including 1PC)
cockroachdb.txn.commits1PC
(count)
[OpenMetrics v1] Number of committed one-phase KV transactions
cockroachdb.txn.commits1PC.count
(count)
[OpenMetrics v2] Number of committed one-phase KV transactions
cockroachdb.txn.durations
(gauge)
[OpenMetrics v1] KV transaction durations in nanoseconds
cockroachdb.txn.durations.bucket
(count)
[OpenMetrics v2] KV transaction durations in nanoseconds
cockroachdb.txn.durations.count
(count)
[OpenMetrics v2] KV transaction durations in nanoseconds
cockroachdb.txn.durations.sum
(count)
[OpenMetrics v2] KV transaction durations in nanoseconds
cockroachdb.txn.restarts
(gauge)
[OpenMetrics v1] Number of restarted KV transactions
cockroachdb.txn.restarts.bucket
(count)
[OpenMetrics v2] Number of restarted KV transactions
cockroachdb.txn.restarts.count
(count)
[OpenMetrics v2] Number of restarted KV transactions
cockroachdb.txn.restarts.sum
(count)
[OpenMetrics v2] Number of restarted KV transactions
cockroachdb.txn.restarts.deleterange
(count)
[OpenMetrics v1] Number of restarts due to a forwarded commit timestamp and a DeleteRange command
cockroachdb.txn.restarts.deleterange.count
(count)
[OpenMetrics v2] Number of restarts due to a forwarded commit timestamp and a DeleteRange command
cockroachdb.txn.restarts.possiblereplay
(count)
[OpenMetrics v1] Number of restarts due to possible replays of command batches at the storage layer
cockroachdb.txn.restarts.possiblereplay.count
(count)
[OpenMetrics v2] Number of restarts due to possible replays of command batches at the storage layer
cockroachdb.txn.restarts.serializable
(count)
[OpenMetrics v1] Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE
cockroachdb.txn.restarts.serializable.count
(count)
[OpenMetrics v2] Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE
cockroachdb.txn.restarts.writetooold
(count)
[OpenMetrics v1] Number of restarts due to a concurrent writer committing first
cockroachdb.txn.restarts.writetooold.count
(count)
[OpenMetrics v2] Number of restarts due to a concurrent writer committing first
cockroachdb.valbytes
(gauge)
[OpenMetrics v1 & v2] Number of bytes taken up by values
Shown as byte
cockroachdb.valcount
(gauge)
[OpenMetrics v1 & v2] Count of all values
cockroachdb.admission.wait.sum.kv
(count)
[OpenMetrics v1] Total KV wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.kv.count
(count)
[OpenMetrics v2] Total KV wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.kv_stores
(count)
[OpenMetrics v1] Total KV stores wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.kv_stores.count
(count)
[OpenMetrics v2] Total KV stores wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.sql_kv.response
(count)
[OpenMetrics v1] Total SQL KV wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.sql_kv.response.count
(count)
[OpenMetrics v2] Total SQL KV wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.sql_sql.response
(count)
[OpenMetrics v1] Total Distributed SQL wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.sql_sql.response.count
(count)
[OpenMetrics v2] Total Distributed SQL wait time in micros
Shown as microsecond
cockroachdb.changefeed.backfill.pending.ranges
(gauge)
[OpenMetrics v1 & v2] Number of ranges in an ongoing backfill that are yet to be fully emitted
cockroachdb.changefeed.backfill
(gauge)
[OpenMetrics v1 & v2] Number of changefeeds currently executing backfill
cockroachdb.changefeed.commit.latency
(gauge)
[OpenMetrics v1] Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink
Shown as nanosecond
cockroachdb.changefeed.commit.latency.bucket
(count)
[OpenMetrics v2] Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink
Shown as nanosecond
cockroachdb.changefeed.commit.latency.count
(count)
[OpenMetrics v2] Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink
Shown as nanosecond
cockroachdb.changefeed.commit.latency.sum
(count)
[OpenMetrics v2] Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink
Shown as nanosecond
cockroachdb.changefeed.emitted.messages
(count)
[OpenMetrics v1] Messages emitted by all feeds
cockroachdb.changefeed.emitted.messages.count
(count)
[OpenMetrics v2] Messages emitted by all feeds
cockroachdb.changefeed.error.retries
(count)
[OpenMetrics v1] Total retryable errors encountered by all changefeeds
cockroachdb.changefeed.error.retries.count
(count)
[OpenMetrics v2] Total retryable errors encountered by all changefeeds
cockroachdb.changefeed.failures
(count)
[OpenMetrics v1] Total number of changefeed jobs which have failed
cockroachdb.changefeed.failures.count
(count)
[OpenMetrics v2] Total number of changefeed jobs which have failed
cockroachdb.changefeed.max.behind.nanos
(gauge)
[OpenMetrics v1 & v2] Largest commit-to-emit duration of any running feed
cockroachdb.changefeed.message.size.hist
(gauge)
[OpenMetrics v1] Message size histogram
cockroachdb.changefeed.message.size.hist.bucket
(count)
[OpenMetrics v2] Message size histogram
cockroachdb.changefeed.message.size.hist.count
(count)
[OpenMetrics v2] Message size histogram
cockroachdb.changefeed.message.size.hist.sum
(count)
[OpenMetrics v2] Message size histogram
cockroachdb.changefeed.running
(gauge)
[OpenMetrics v1 & v2] Number of currently running changefeeds, including sinkless
cockroachdb.jobs.changefeed.resume.retry.error
(count)
[OpenMetrics v1] Number of changefeed jobs which failed with a retriable error
cockroachdb.jobs.changefeed.resume.retry.error.count
(count)
[OpenMetrics v2] Number of changefeed jobs which failed with a retriable error
cockroachdb.ranges.overreplicated
(gauge)
[OpenMetrics v1 & v2] Number of ranges with more live replicas than the replication target
cockroachdb.sql.conn.latency
(gauge)
[OpenMetrics v1] Latency to establish and authenticate a SQL connection
Shown as nanosecond
cockroachdb.sql.conn.latency.bucket
(count)
[OpenMetrics v2] Latency to establish and authenticate a SQL connection
Shown as nanosecond
cockroachdb.sql.conn.latency.count
(count)
[OpenMetrics v2] Latency to establish and authenticate a SQL connection
Shown as nanosecond
cockroachdb.sql.conn.latency.sum
(count)
[OpenMetrics v2] Latency to establish and authenticate a SQL connection
Shown as nanosecond
cockroachdb.sql.distsql.contended.queries
(count)
[OpenMetrics v1] Number of SQL queries that experienced contention
cockroachdb.sql.distsql.contended.queries.count
(count)
[OpenMetrics v2] Number of SQL queries that experienced contention0
cockroachdb.sql.failure
(count)
[OpenMetrics v1] Number of statements resulting in a planning or runtime error
cockroachdb.sql.failure.count
(count)
[OpenMetrics v2] Number of statements resulting in a planning or runtime error
cockroachdb.sql.full.scan
(count)
[OpenMetrics v1] Number of full table or index scans
cockroachdb.sql.full.scan.count
(count)
[OpenMetrics v2] Number of full table or index scans
cockroachdb.sql.statements.active
(gauge)
[OpenMetrics v1 & v2] Number of currently active user SQL statements
cockroachdb.sql.txn.latency
(gauge)
[OpenMetrics v1] Latency of SQL transactions
Shown as transaction
cockroachdb.sql.txn.latency.bucket
(count)
[OpenMetrics v2] Latency of SQL transactions
Shown as transaction
cockroachdb.sql.txn.latency.count
(count)
[OpenMetrics v2] Latency of SQL transactions
Shown as transaction
cockroachdb.sql.txn.latency.sum
(count)
[OpenMetrics v2] Latency of SQL transactions
Shown as transaction
cockroachdb.sql.txns.open
(gauge)
[OpenMetrics v1 & v2] Number of currently open user SQL transactions
Shown as transaction
cockroachdb.sys.cpu.combined.percent.normalized
(gauge)
[OpenMetrics v1 & v2] Current user+system cpu percentage, normalized 0-1 by number of cores
Shown as fraction
cockroachdb.sys.host.net.recv.bytes
(gauge)
[OpenMetrics v1 & v2] Bytes received on all network interfaces since this process started
Shown as byte
cockroachdb.sys.host.net.send.bytes
(gauge)
[OpenMetrics v1 & v2] Bytes sent on all network interfaces since this process started
Shown as byte
cockroachdb.sys.host.disk.read.bytes
(gauge)
[OpenMetrics v1 & v2] Bytes read from all disks since this process started
Shown as byte
cockroachdb.sys.host.disk.write.bytes
(gauge)
[OpenMetrics v1 & v2] Bytes written to all disks since this process started
Shown as byte
cockroachdb.admission.admitted.kv
(count)
[OpenMetrics v1] Number of KV requests admitted
Shown as request
cockroachdb.admission.admitted.kv.count
(count)
[OpenMetrics v2] Number of KV requests admitted
Shown as request
cockroachdb.admission.admitted.kv_stores
(count)
[OpenMetrics v1] Number of KV stores requests admitted
Shown as request
cockroachdb.admission.admitted.kv_stores.count
(count)
[OpenMetrics v2] Number of KV stores requests admitted
Shown as request
cockroachdb.admission.admitted.sql_kv.response
(count)
[OpenMetrics v1] Number of SQL KV response requests admitted
Shown as request
cockroachdb.admission.admitted.sql_kv.response.count
(count)
[OpenMetrics v2] Number of SQL KV response requests admitted
Shown as request
cockroachdb.admission.admitted.sql.leaf.start
(count)
[OpenMetrics v1] Number of SQL leaf start requests admitted
Shown as request
cockroachdb.admission.admitted.sql.leaf.start.count
(count)
[OpenMetrics v2] Number of SQL leaf start requests admitted
Shown as request
cockroachdb.admission.admitted.sql.root.start
(count)
[OpenMetrics v1] Number of SQL root start requests admitted
Shown as request
cockroachdb.admission.admitted.sql.root.start.count
(count)
[OpenMetrics v2] Number of SQL root start requests admitted
Shown as request
cockroachdb.admission.admitted.sql_sql.response
(count)
[OpenMetrics v1] Number of Distributed SQL response requests admitted
Shown as request
cockroachdb.admission.admitted.sql_sql.response.count
(count)
[OpenMetrics v2] Number of Distributed SQL response requests admitted
Shown as request
cockroachdb.admission.errored.kv
(count)
[OpenMetrics v1] Number of KV requests not admitted due to error
Shown as request
cockroachdb.admission.errored.kv.count
(count)
[OpenMetrics v2] Number of KV requests not admitted due to error
Shown as request
cockroachdb.admission.errored.kv_stores
(count)
[OpenMetrics v1] Number of KV stores requests not admitted due to error
Shown as request
cockroachdb.admission.errored.kv_stores.count
(count)
[OpenMetrics v2] Number of KV stores requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql_kv.response
(count)
[OpenMetrics v1] Number of SQL KV requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql_kv.response.count
(count)
[OpenMetrics v2] Number of SQL KV requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql.leaf.start
(count)
[OpenMetrics v1] Number of SQL leaf start requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql.leaf.start.count
(count)
[OpenMetrics v2] Number of SQL leaf start requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql.root.start
(count)
[OpenMetrics v1] Number of SQL root start requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql.root.start.count
(count)
[OpenMetrics v2] Number of SQL root start requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql_sql.response
(count)
[OpenMetrics v1] Number of Distributed SQL requests not admitted due to error
Shown as request
cockroachdb.admission.errored.sql_sql.response.count
(count)
[OpenMetrics v2] Number of Distributed SQL start requests not admitted due to error
Shown as request
cockroachdb.admission.granter.io.tokens.exhausted.duration.kv
(count)
[OpenMetrics v1] Total duration when IO tokens were exhausted, in micros
Shown as microsecond
cockroachdb.admission.granter.io.tokens.exhausted.duration.kv.count
(count)
[OpenMetrics v2] Total duration when IO tokens were exhausted, in micros
Shown as microsecond
cockroachdb.admission.granter.total.slots.kv
(gauge)
[OpenMetrics v1 & v2] Total slots for KV work
cockroachdb.admission.granter.used.slots.kv
(gauge)
[OpenMetrics v1 & v2] Used slots for KV work
cockroachdb.admission.granter.used.slots.sql.leaf.start
(gauge)
[OpenMetrics v1 & v2] Used slots for SQL leaf start work
cockroachdb.admission.granter.used.slots.sql.root.start
(gauge)
[OpenMetrics v1 & v2] Used slots for SQL root start work
cockroachdb.admission.requested.kv
(count)
[OpenMetrics v1] Number of KV admission requests
Shown as request
cockroachdb.admission.requested.kv.count
(count)
[OpenMetrics v2] Number of KV admission requests
Shown as request
cockroachdb.admission.requested.kv_stores
(count)
[OpenMetrics v1] Number of KV stores admission requests
Shown as request
cockroachdb.admission.requested.kv_stores.count
(count)
[OpenMetrics v2] Number of KV stores admission requests
Shown as request
cockroachdb.admission.requested.sql_kv.response
(count)
[OpenMetrics v1] Number of SQL KV admission requests
Shown as request
cockroachdb.admission.requested.sql_kv.response.count
(count)
[OpenMetrics v2] Number of SQL KV admission requests
Shown as request
cockroachdb.admission.requested.sql.leaf.start
(count)
[OpenMetrics v1] Number of SQL leaf start admission requests
Shown as request
cockroachdb.admission.requested.sql.leaf.start.count
(count)
[OpenMetrics v2] Number of SQL leaf start admission requests
Shown as request
cockroachdb.admission.requested.sql_sql.response
(count)
[OpenMetrics v1] Number of Distributed SQL admission requests
Shown as request
cockroachdb.admission.requested.sql_sql.response.count
(count)
[OpenMetrics v2] Number of Distributed SQL admission requests
Shown as request
cockroachdb.admission.wait.durations.kv
(gauge)
[OpenMetrics v1] Wait time durations for KV requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv.bucket
(count)
[OpenMetrics v2] Wait time durations for KV requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv.count
(count)
[OpenMetrics v2] Wait time durations for KV requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv.sum
(count)
[OpenMetrics v2] Wait time durations for KV requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv_stores
(gauge)
[OpenMetrics v1] Wait time durations for KV stores requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv_stores.bucket
(count)
[OpenMetrics v2] Wait time durations for KV stores requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv_stores.count
(count)
[OpenMetrics v2] Wait time durations for KV stores requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.kv_stores.sum
(count)
[OpenMetrics v2] Wait time durations for KV stores requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_kv.response
(gauge)
[OpenMetrics v1] Wait time durations for SQL KV response requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_kv.response.bucket
(count)
[OpenMetrics v2] Wait time durations for SQL KV response requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_kv.response.count
(count)
[OpenMetrics v2] Wait time durations for SQL KV response requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_kv.response.sum
(count)
[OpenMetrics v2] Wait time durations for SQL KV response requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql.leaf.start
(gauge)
[OpenMetrics v1] Wait time durations for SQL leaf start requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql.leaf.start.bucket
(count)
[OpenMetrics v2] Wait time durations for SQL leaf start requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql.leaf.start.count
(count)
[OpenMetrics v2] Wait time durations for SQL leaf start requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql.leaf.start.sum
(count)
[OpenMetrics v2] Wait time durations for SQL leaf start requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_sql.response
(gauge)
[OpenMetrics v1] Wait time durations for Distributed SQL requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_sql.response.bucket
(count)
[OpenMetrics v2] Wait time durations for Distributed SQL requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_sql.response.count
(count)
[OpenMetrics v2] Wait time durations for Distributed SQL requests that waited
Shown as nanosecond
cockroachdb.admission.wait.durations.sql_sql.response.sum
(count)
[OpenMetrics v2] Wait time durations for Distributed SQL requests that waited
Shown as nanosecond
cockroachdb.admission.wait.queue.length.kv_stores
(gauge)
[OpenMetrics v1 & v2] Length of KV stores wait queue
cockroachdb.admission.wait.queue.length.kv
(gauge)
[OpenMetrics v1 & v2] Length of KV wait queue
cockroachdb.admission.wait.queue.length.sql_kv.response
(gauge)
[OpenMetrics v1 & v2] Length of SQL KV wait queue
cockroachdb.admission.wait.queue.length.sql.leaf.start
(gauge)
[OpenMetrics v1 & v2] Length of SQL leaf start wait queue
cockroachdb.admission.wait.queue.length.sql_sql.response
(gauge)
[OpenMetrics v1 & v2] Length of Distributed SQL wait queue
cockroachdb.admission.wait.queue.lengths.sql.root.start
(gauge)
[OpenMetrics v1 & v2] Length of SQL root start wait queue
cockroachdb.admission.wait.sum.sql.root.start
(count)
[OpenMetrics v1] Total SQL root start wait time in micros
Shown as microsecond
cockroachdb.admission.wait.sum.sql.root.start.count
(count)
[OpenMetrics v2] Total SQL root start wait time in micros
Shown as microsecond
cockroachdb.changefeed.admit.latency
(gauge)
[OpenMetrics v1] Event admission latency: a difference between event MVCC timestamp and the time it was admitted into changefeed pipeline
Shown as nanosecond
cockroachdb.changefeed.admit.latency.bucket
(count)
[OpenMetrics v2] Event admission latency: a difference between event MVCC timestamp and the time it was admitted into changefeed pipeline
Shown as nanosecond
cockroachdb.changefeed.admit.latency.count
(count)
[OpenMetrics v2] Event admission latency: a difference between event MVCC timestamp and the time it was admitted into changefeed pipeline
Shown as nanosecond
cockroachdb.changefeed.admit.latency.sum
(count)
[OpenMetrics v2] Event admission latency: a difference between event MVCC timestamp and the time it was admitted into changefeed pipeline
Shown as nanosecond
cockroachdb.jobs.backup.currently_idle
(gauge)
[OpenMetrics v1 & v2] Number of backup jobs currently considered Idle and can be freely shut down
Shown as job
cockroachdb.jobs.backup.currently_running
(gauge)
[OpenMetrics v1 & v2] Number of backup jobs currently running in Resume or OnFailOrCancel state
Shown as job
cockroachdb.jobs.backup.fail_or_cancel_failed
(count)
[OpenMetrics v1] Number of backup jobs which failed with a non-retriable error on their failure or cancelation process
Shown as job
cockroachdb.jobs.backup.fail_or_cancel_failed.count
(count)
[OpenMetrics v2] Number of backup jobs which failed with a non-retriable error on their failure or cancelation process
Shown as job
cockroachdb.jobs.backup.fail_or_cancel_retry_error
(count)
[OpenMetrics v1] Number of backup jobs which failed with a retriable error on their failure or cancelation process
Shown as job
cockroachdb.jobs.backup.fail_or_cancel_retry_error.count
(count)
[OpenMetrics v2] Number of backup jobs which failed with a retriable error on their failure or cancelation process
Shown as job
cockroachdb.jobs.backup.resume_failed
(count)
[OpenMetrics v1] Number of backup jobs which failed with a non-retriable error
Shown as job
cockroachdb.jobs.backup.resume_failed.count
(count)
[OpenMetrics v2] Number of backup jobs which failed with a non-retriable error
Shown as job
cockroachdb.jobs.backup.resume_retry_error
(count)
[OpenMetrics v1] Number of backup jobs which failed with a retriable error
Shown as job
cockroachdb.jobs.backup.resume_retry_error.count
(count)
[OpenMetrics v2] Number of backup jobs which failed with a retriable error
Shown as job
cockroachdb.schedules.backup.last_completed_time
(gauge)
[OpenMetrics v1 & v2] The unix timestamp of the most recently completed backup by a schedule specified as maintaining this metric
Shown as second
cockroachdb.changefeed.emitted_bytes.count
(count)
Bytes emitted by all feeds
cockroachdb.jobs.auto.create.stats.currently_running
(gauge)
Number of autocreatestats jobs currently running in Resume or OnFailOrCancel state
cockroachdb.jobs.auto.create.stats.resume_failed.count
(count)
Number of autocreatestats jobs which failed with a non-retriable error
cockroachdb.jobs.create.stats.currently_running
(gauge)
Number of create_stats jobs currently running in Resume or OnFailOrCancel state
cockroachdb.jobs.row.level.ttl.currently_running
(gauge)
Number of rowlevelttl jobs currently running in Resume or OnFailOrCancel state
cockroachdb.jobs.row.level.ttl.resume_completed.count
(count)
Number of rowlevelttl jobs which successfully resumed to completion
cockroachdb.jobs.row.level.ttl.resume_failed.count
(count)
Number of rowlevelttl jobs which failed with a non-retriable error
cockroachdb.jobs.row.level.ttl.rows_deleted.count
(count)
Number of rows deleted by the row level TTL job.
cockroachdb.jobs.row.level.ttl.rows_selected.count
(count)
Number of rows selected for deletion by the row level TTL job.
cockroachdb.range.merges.count
(count)
Number of range merges
cockroachdb.rebalancing.queriespersecond
(gauge)
Number of kv-level requests received per second by the store, averaged over a large time period as used in rebalancing decisions
cockroachdb.schedules.scheduled.row.level.ttl.executor_failed.count
(count)
Number of scheduled-row-level-ttl-executor jobs failed
cockroachdb.seconds.until.enterprise.license.expiry
(gauge)
Seconds until enterprise license expiry (0 if no license present or running without enterprise features)
cockroachdb.sql.mem.root.current
(gauge)
Current sql statement memory usage for root
cockroachdb.sql.new_conns.count
(count)
Counter of the number of sql connections created
cockroachdb.storage.write.stalls
(gauge)
Number of instances of intentional write stalls to backpressure incoming writes
cockroachdb.sys.host.disk.read
(gauge)
Disk read operations across all disks since this process started
cockroachdb.sys.host.disk.write
(gauge)
Disk write operations across all disks since this process started
cockroachdb.sys.host.disk.iopsinprogress
(gauge)
IO operations currently in progress on this host
cockroachdb.sys.runnable.goroutines.per_cpu
(gauge)
Average number of goroutines that are waiting to run, normalized by number of cores
cockroachdb.txn.restarts.txnaborted.count
(count)
Number of restarts due to an abort by a concurrent transaction (usually due to deadlock)
cockroachdb.txn.restarts.txnpush.count
(count)
Number of restarts due to a transaction push failure
cockroachdb.txn.restarts.writetoooldmulti.count
(count)
Number of restarts due to multiple concurrent writers committing first
cockroachdb.txn.restarts.unknown.count
(count)
Number of restarts due to a unknown reasons
cockroachdb.txnwaitqueue.deadlocks.count
(count)
Number of deadlocks detected by the txn wait queue
cockroachdb.security.certificate_expiration.ca
(gauge)
Expiration for the CA certificate. 0 means no certificate or error
cockroachdb.security.certificate_expiration.client_ca
(gauge)
Expiration for the client CA certificate. 0 means no certificate or error
cockroachdb.security.certificate_expiration.ui
(gauge)
Expiration for the UI certificate. 0 means no certificate or error
cockroachdb.security.certificate_expiration.ui_ca
(gauge)
Expiration for the UI CA certificate. 0 means no certificate or error
cockroachdb.security.certificate_expiration.node
(gauge)
Expiration for the node certificate. 0 means no certificate or error
cockroachdb.security.certificate_expiration.node_client
(gauge)
Expiration for the node's client certificate. 0 means no certificate or error
cockroachdb.admission.io.overload
(gauge)
1-normalized float indicating whether IO admission control considers the store as overloaded with respect to compaction out of L0 (considers sub-level and file counts).
cockroachdb.jobs.auto.create.stats.currently_paused
(gauge)
Number of autocreatestats jobs currently considered Paused
cockroachdb.jobs.backup.currently_paused
(gauge)
Number of backup jobs currently considered Paused
cockroachdb.jobs.changefeed.currently_paused
(gauge)
Number of changefeed jobs currently considered Paused
cockroachdb.jobs.changefeed.protected_age_sec
(gauge)
The age of the oldest PTS record protected by changefeed jobs
cockroachdb.jobs.row.level.ttl.currently_paused
(gauge)
Number of rowlevelttl jobs currently considered Paused
cockroachdb.queue.replicate.replacedecommissioningreplica.error.count
(count)
Number of failed decommissioning replica replica replacements processed by the replicate queue

Checks de service

Le check CockroachDB n’inclut aucun check de service.

Événements

Le check CockroachDB n’inclut aucun événement.

Dépannage

Besoin d’aide ? Contactez l’assistance Datadog .

Pour aller plus loin

Documentation, liens et articles supplémentaires utiles :