Overview

Datadog products and visualizations are built on metrics and tags that adhere to specific naming patterns. Metrics from OpenTelemetry components that are sent to Datadog are mapped to corresponding Datadog metrics, as applicable. The creation of these additional metrics does not affect Datadog billing.

The following diagram shows the process of mapping the metrics from OpenTelemetry into metrics that Datadog uses:

The decision process for mapping OpenTelemetry metric names to Datadog metric names. If an OTel metric is not used by any Datadog product, or if its semantics are the same as Datadog's, it is sent as-is to Datadog. Otherwise, a Datadog-style metric is created from the OTel metric and sent to Datadog.

Use of the otel prefix

To differentiate the metrics captured by the hostmetrics receiver from Datadog Agent, we add a prefix, otel, for metrics collected by the collector. If a metric name starts with system. or process., otel. is prepended to the metric name. Monitoring the same infrastructure artifact using both Agent and Collector is not recommended.

Datadog is evaluating ways to improve the OTLP metric experience, including potentially deprecating this otel prefix. If you have feedback related to this, reach out your account team to provide your input.

Metrics mappings

Metrics mappings between Datadog and OpenTelemetry are defined on OTel integration pages. Select the integration you are using for more information.

oteldatadogdescriptionfiltertransformIntegration
apache.cpu.loadapache.performance.cpu_loadCurrent load of the CPU.apache
apache.current_connectionsapache.conns_totalThe number of active connections currently attached to the HTTP server.apache
apache.requestsapache.net.request_per_sThe number of requests serviced by the HTTP server per second.apache
apache.scoreboardapache.scoreboard.sending_replyThe number of workers in each state.state: sendingapache
apache.scoreboardapache.scoreboard.reading_requestThe number of workers in each state.state: readingapache
apache.scoreboardapache.scoreboard.open_slotThe number of workers in each state.state: openapache
apache.scoreboardapache.scoreboard.loggingThe number of workers in each state.state: loggingapache
apache.scoreboardapache.scoreboard.keepaliveThe number of workers in each state.state: keepaliveapache
apache.scoreboardapache.scoreboard.idle_cleanupThe number of workers in each state.state: idle_cleanupapache
apache.scoreboardapache.scoreboard.gracefully_finishingThe number of workers in each state.state: finishingapache
apache.scoreboardapache.scoreboard.dns_lookupThe number of workers in each state.state: dnslookupapache
apache.scoreboardapache.scoreboard.closing_connectionThe number of workers in each state.state: closingapache
apache.scoreboardapache.scoreboard.starting_upThe number of workers in each state.state: startingapache
apache.scoreboardapache.scoreboard.waiting_for_connectionThe number of workers in each state.state: waitingapache
apache.uptimeapache.performance.uptimeThe amount of time that the server has been running in seconds.apache
apache.workersapache.performance.idle_workersThe number of workers currently attached to the HTTP server.workers_state: idleapache
apache.workersapache.performance.busy_workersThe number of workers currently attached to the HTTP server.workers_state: busyapache
spark.driver.block_manager.disk.usagespark.driver.disk_usedDisk space used by the BlockManager.× 1048576apachespark
spark.driver.block_manager.memory.usagespark.driver.memory_usedMemory usage for the driver’s BlockManager.× 1048576apachespark
spark.driver.dag_scheduler.stage.countspark.stage.countNumber of stages the DAGScheduler is either running or needs to run.apachespark
spark.executor.disk.usagespark.executor.disk_usedDisk space used by this executor for RDD storage.apachespark
spark.executor.disk.usagespark.rdd.disk_usedDisk space used by this executor for RDD storage.apachespark
spark.executor.memory.usagespark.executor.memory_usedStorage memory used by this executor.apachespark
spark.executor.memory.usagespark.rdd.memory_usedStorage memory used by this executor.apachespark
spark.job.stage.activespark.job.num_active_stagesNumber of active stages in this job.apachespark
spark.job.stage.resultspark.job.num_completed_stagesNumber of stages with a specific result in this job.job_result: completedapachespark
spark.job.stage.resultspark.job.num_failed_stagesNumber of stages with a specific result in this job.job_result: failedapachespark
spark.job.stage.resultspark.job.num_skipped_stagesNumber of stages with a specific result in this job.job_result: skippedapachespark
spark.job.task.activespark.job.num_tasks{status: running}Number of active tasks in this job.apachespark
spark.job.task.resultspark.job.num_skipped_tasksNumber of tasks with a specific result in this job.job_result: skippedapachespark
spark.job.task.resultspark.job.num_failed_tasksNumber of tasks with a specific result in this job.job_result: failedapachespark
spark.job.task.resultspark.job.num_completed_tasksNumber of tasks with a specific result in this job.job_result: completedapachespark
spark.stage.io.recordsspark.stage.input_recordsNumber of records written and read in this stage.direction: inapachespark
spark.stage.io.recordsspark.stage.output_recordsNumber of records written and read in this stage.direction: outapachespark
spark.stage.io.sizespark.stage.input_bytesAmount of data written and read at this stage.direction: inapachespark
spark.stage.io.sizespark.stage.output_bytesAmount of data written and read at this stage.direction: outapachespark
spark.stage.shuffle.io.read.sizespark.stage.shuffle_read_bytesAmount of data read in shuffle operations in this stage.apachespark
spark.stage.shuffle.io.recordsspark.stage.shuffle_read_recordsNumber of records written or read in shuffle operations in this stage.direction: inapachespark
spark.stage.shuffle.io.recordsspark.stage.shuffle_write_recordsNumber of records written or read in shuffle operations in this stage.direction: outapachespark
abortspanbytescockroachdb.abortspanbytesNumber of bytes in the abort spancockroachdb
addsstable_applicationscockroachdb.addsstable.applications.countNumber of SSTable ingestions applied (i.e. applied by Replicas)cockroachdb
addsstable_copiescockroachdb.addsstable.copies.countnumber of SSTable ingestions that required copying files during applicationcockroachdb
addsstable_delay_enginebackpressurecockroachdb.addsstable.delay.enginebackpressure.countAmount by which evaluation of AddSSTable requests was delayed by storage-engine backpressurecockroachdb
addsstable_proposalscockroachdb.addsstable.proposals.countNumber of SSTable ingestions proposed (i.e. sent to Raft by lease holders)cockroachdb
admission_admitted_elastic_cpucockroachdb.admission.admitted.elastic_cpu.countNumber of requests admittedcockroachdb
admission_admitted_elastic_cpu_bulk_normal_pricockroachdb.admission.admitted.elastic_cpu.bulk_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_elastic_cpu_normal_pricockroachdb.admission.admitted.elastic_cpu.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_kvcockroachdb.admission.admitted.kv.countNumber of requests admittedcockroachdb
admission_admitted_kv_high_pricockroachdb.admission.admitted.kv.high_pri.countNumber of requests admittedcockroachdb
admission_admitted_kv_locking_normal_pricockroachdb.admission.admitted.kv.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_kv_normal_pricockroachdb.admission.admitted.kv.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_kv_storescockroachdb.admission.admitted.kv_stores.countNumber of requests admittedcockroachdb
admission_admitted_kv_stores_high_pricockroachdb.admission.admitted.kv_stores.high_pri.countNumber of requests admittedcockroachdb
admission_admitted_kv_stores_locking_normal_pricockroachdb.admission.admitted.kv_stores.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_kv_stores_normal_pricockroachdb.admission.admitted.kv_stores.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_kv_responsecockroachdb.admission.admitted.sql_kv.response.countNumber of requests admittedcockroachdb
admission_admitted_sql_kv_response_locking_normal_pricockroachdb.admission.admitted.sql_kv_response.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_kv_response_normal_pricockroachdb.admission.admitted.sql_kv_response.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_leaf_startcockroachdb.admission.admitted.sql.leaf.start.countNumber of requests admittedcockroachdb
admission_admitted_sql_leaf_startcockroachdb.admission.admitted.sql_leaf_start.countNumber of requests admittedcockroachdb
admission_admitted_sql_leaf_start_locking_normal_pricockroachdb.admission.admitted.sql_leaf_start.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_leaf_start_normal_pricockroachdb.admission.admitted.sql_leaf_start.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_root_startcockroachdb.admission.admitted.sql_root_start.countNumber of requests admittedcockroachdb
admission_admitted_sql_root_startcockroachdb.admission.admitted.sql.root.start.countNumber of requests admittedcockroachdb
admission_admitted_sql_root_start_locking_normal_pricockroachdb.admission.admitted.sql_root_start.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_root_start_normal_pricockroachdb.admission.admitted.sql_root_start.normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_sql_responsecockroachdb.admission.admitted.sql_sql.response.countNumber of requests admittedcockroachdb
admission_admitted_sql_sql_response_locking_normal_pricockroachdb.admission.admitted.sql_sql_response.locking_normal_pri.countNumber of requests admittedcockroachdb
admission_admitted_sql_sql_response_normal_pricockroachdb.admission.admitted.sql_sql_response.normal_pri.countNumber of requests admittedcockroachdb
admission_elastic_cpu_acquired_nanoscockroachdb.admission.elastic_cpu.acquired_nanos.countTotal CPU nanoseconds acquired by elastic workcockroachdb
admission_elastic_cpu_available_nanoscockroachdb.admission.elastic_cpu.available_nanosInstantaneous available CPU nanoseconds per second ignoring utilization limitcockroachdb
admission_elastic_cpu_max_available_nanoscockroachdb.admission.elastic_cpu.max_available_nanos.countMaximum available CPU nanoseconds per second ignoring utilization limitcockroachdb
admission_elastic_cpu_nanos_exhausted_durationcockroachdb.admission.elastic_cpu.nanos_exhausted_durationTotal duration when elastic CPU nanoseconds were exhausted, in microscockroachdb
admission_elastic_cpu_over_limit_durationscockroachdb.admission.elastic_cpu.over_limit_durations.countMeasurement of how much over the prescribed limit elastic requests ran (not recorded if requests don’t run over)cockroachdb
admission_elastic_cpu_pre_work_nanoscockroachdb.admission.elastic_cpu.pre_work_nanos.countTotal CPU nanoseconds spent doing pre-work, before doing elastic workcockroachdb
admission_elastic_cpu_returned_nanoscockroachdb.admission.elastic_cpu.returned_nanos.countTotal CPU nanoseconds returned by elastic workcockroachdb
admission_elastic_cpu_utilizationcockroachdb.admission.elastic_cpu.utilizationCPU utilization by elastic workcockroachdb
admission_elastic_cpu_utilization_limitcockroachdb.admission.elastic_cpu.utilization_limitUtilization limit set for the elastic CPU workcockroachdb
admission_errored_elastic_cpucockroachdb.admission.errored.elastic_cpu.countNumber of requests not admitted due to errorcockroachdb
admission_errored_elastic_cpu_bulk_normal_pricockroachdb.admission.errored.elastic_cpu.bulk_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_elastic_cpu_normal_pricockroachdb.admission.errored.elastic_cpu.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kvcockroachdb.admission.errored.kv.counttNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_high_pricockroachdb.admission.errored.kv.high_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_locking_normal_pricockroachdb.admission.errored.kv.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_normal_pricockroachdb.admission.errored.kv.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_storescockroachdb.admission.errored.kv_stores.counttNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_stores_high_pricockroachdb.admission.errored.kv_stores.high_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_stores_locking_normal_pricockroachdb.admission.errored.kv_stores.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_kv_stores_normal_pricockroachdb.admission.errored.kv_stores.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_kv_responsecockroachdb.admission.errored.sql_kv.response.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_kv_response_locking_normal_pricockroachdb.admission.errored.sql_kv_response.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_kv_response_normal_pricockroachdb.admission.errored.sql_kv_response.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_leaf_startcockroachdb.admission.errored.sql.leaf.start.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_leaf_startcockroachdb.admission.errored.sql_leaf_start.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_leaf_start_locking_normal_pricockroachdb.admission.errored.sql_leaf_start.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_leaf_start_normal_pricockroachdb.admission.errored.sql_leaf_start.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_root_startcockroachdb.admission.errored.sql_root_start.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_root_startcockroachdb.admission.errored.sql.root.start.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_root_start_locking_normal_pricockroachdb.admission.errored.sql_root_start.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_root_start_normal_pricockroachdb.admission.errored.sql_root_start.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_sql_responsecockroachdb.admission.errored.sql_sql.response.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_sql_response_locking_normal_pricockroachdb.admission.errored.sql_sql_response.locking_normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_errored_sql_sql_response_normal_pricockroachdb.admission.errored.sql_sql_response.normal_pri.countNumber of requests not admitted due to errorcockroachdb
admission_granter_cpu_load_long_period_duration_kvcockroachdb.admission.granter.cpu_load_long_period_duration.kv.countTotal duration when CPULoad was being called with a long period, in microscockroachdb
admission_granter_cpu_load_short_period_duration_kvcockroachdb.admission.granter.cpu_load_short_period_duration.kv.countTotal duration when CPULoad was being called with a short period, in microscockroachdb
admission_granter_elastic_io_tokens_available_kvcockroachdb.admission.granter.elastic_io_tokens_available.kvNumber of tokens availablecockroachdb
admission_granter_io_tokens_available_kvcockroachdb.admission.granter.io_tokens_available.kvNumber of tokens availablecockroachdb
admission_granter_io_tokens_bypassed_kvcockroachdb.admission.granter.io_tokens_bypassed.kv.countTotal number of tokens taken by work bypassing admission control (for example, follower writes without flow control)cockroachdb
admission_granter_io_tokens_exhausted_duration_kvcockroachdb.admission.granter.io_tokens_exhausted_duration.kv.countTotal duration when IO tokens were exhausted, in microscockroachdb
admission_granter_io_tokens_exhausted_duration_kvcockroachdb.admission.granter.io.tokens.exhausted.duration.kv.countTotal duration when IO tokens were exhausted, in microscockroachdb
admission_granter_io_tokens_returned_kvcockroachdb.admission.granter.io_tokens_returned.kv.countTotal number of tokens returnedcockroachdb
admission_granter_io_tokens_taken_kvcockroachdb.admission.granter.io_tokens_taken.kv.countTotal number of tokens takencockroachdb
admission_granter_slot_adjuster_decrements_kvcockroachdb.admission.granter.slot_adjuster_decrements.kv.countNumber of decrements of the total KV slotscockroachdb
admission_granter_slot_adjuster_increments_kvcockroachdb.admission.granter.slot_adjuster_increments.kv.countNumber of increments of the total KV slotscockroachdb
admission_granter_slots_exhausted_duration_kvcockroachdb.admission.granter.slots_exhausted_duration.kv.countTotal duration when KV slots were exhausted, in microscockroachdb
admission_granter_total_slots_kvcockroachdb.admission.granter.total.slots.kvTotal slots for kv workcockroachdb
admission_granter_total_slots_kvcockroachdb.admission.granter.total_slots.kvTotal slots for kv workcockroachdb
admission_granter_used_slots_kvcockroachdb.admission.granter.used_slots.kvUsed slotscockroachdb
admission_granter_used_slots_kvcockroachdb.admission.granter.used.slots.kvUsed slotscockroachdb
admission_granter_used_slots_sql_leaf_startcockroachdb.admission.granter.used.slots.sql.leaf.startUsed slotscockroachdb
admission_granter_used_slots_sql_leaf_startcockroachdb.admission.granter.used_slots.sql_leaf_startUsed slotscockroachdb
admission_granter_used_slots_sql_root_startcockroachdb.admission.granter.used_slots.sql_root_startUsed slotscockroachdb
admission_granter_used_slots_sql_root_startcockroachdb.admission.granter.used.slots.sql.root.startUsed slotscockroachdb
admission_io_overloadcockroachdb.admission.io.overload1-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
admission_l0_compacted_bytes_kvcockroachdb.admission.l0_compacted_bytes.kv.countTotal bytes compacted out of L0 (used to generate IO tokens)cockroachdb
admission_l0_tokens_produced_kvcockroachdb.admission.l0_tokens_produced.kv.countTotal bytes produced for L0 writescockroachdb
admission_raft_paused_replicascockroachdb.admission.raft.paused_replicasNumber of followers (i.e. Replicas) to which replication is currently paused to help them recover from I/O overload. Such Replicas will be ignored for the purposes of proposal quota, and will not receive replication traffic. They are essentially treated as offline for the purpose of replication. This serves as a crude form of admission control. The count is emitted by the leaseholder of each range.cockroachdb
admission_raft_paused_replicas_dropped_msgscockroachdb.admission.raft.paused_replicas_dropped_msgs.countNumber of messages dropped instead of being sent to paused replicas. The messages are dropped to help these replicas to recover from I/O overload.cockroachdb
admission_requested_elastic_cpucockroachdb.admission.requested.elastic_cpu.countNumber of requestscockroachdb
admission_requested_elastic_cpu_bulk_normal_pricockroachdb.admission.requested.elastic_cpu.bulk_normal_pri.countNumber of requestscockroachdb
admission_requested_elastic_cpu_normal_pricockroachdb.admission.requested.elastic_cpu.normal_pri.countNumber of requestscockroachdb
admission_requested_kvcockroachdb.admission.requested.kv.countNumber of requestscockroachdb
admission_requested_kv_high_pricockroachdb.admission.requested.kv.high_pri.countNumber of requestscockroachdb
admission_requested_kv_locking_normal_pricockroachdb.admission.requested.kv.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_kv_normal_pricockroachdb.admission.requested.kv.normal_pri.countNumber of requestscockroachdb
admission_requested_kv_storescockroachdb.admission.requested.kv_stores.countNumber of requestscockroachdb
admission_requested_kv_stores_high_pricockroachdb.admission.requested.kv_stores.high_pri.countNumber of requestscockroachdb
admission_requested_kv_stores_locking_normal_pricockroachdb.admission.requested.kv_stores.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_kv_stores_normal_pricockroachdb.admission.requested.kv_stores.normal_pri.countNumber of requestscockroachdb
admission_requested_sql_kv_responsecockroachdb.admission.requested.sql_kv.response.countNumber of requestscockroachdb
admission_requested_sql_kv_response_locking_normal_pricockroachdb.admission.requested.sql_kv_response.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_sql_kv_response_normal_pricockroachdb.admission.requested.sql_kv_response.normal_pri.countNumber of requestscockroachdb
admission_requested_sql_leaf_startcockroachdb.admission.requested.sql.leaf.start.countNumber of requestscockroachdb
admission_requested_sql_leaf_start_locking_normal_pricockroachdb.admission.requested.sql_leaf_start.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_sql_leaf_start_normal_pricockroachdb.admission.requested.sql_leaf_start.normal_pri.countNumber of requestscockroachdb
admission_requested_sql_root_startcockroachdb.admission.requested.sql_root_start.countNumber of requestscockroachdb
admission_requested_sql_root_start_locking_normal_pricockroachdb.admission.requested.sql_root_start.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_sql_root_start_normal_pricockroachdb.admission.requested.sql_root_start.normal_pri.countNumber of requestscockroachdb
admission_requested_sql_sql_responsecockroachdb.admission.requested.sql_sql.response.countNumber of requestscockroachdb
admission_requested_sql_sql_response_locking_normal_pricockroachdb.admission.requested.sql_sql_response.locking_normal_pri.countNumber of requestscockroachdb
admission_requested_sql_sql_response_normal_pricockroachdb.admission.requested.sql_sql_response.normal_pri.countNumber of requestscockroachdb
admission_scheduler_latency_listener_p99_nanoscockroachdb.admission.scheduler_latency_listener.p99_nanosThe scheduling latency at p99 as observed by the scheduler latency listenercockroachdb
admission_wait_durations_elastic_cpucockroachdb.admission.wait_durations.elastic_cpu.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_elastic_cpu_bulk_normal_pricockroachdb.admission.wait_durations.elastic_cpu.bulk_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_elastic_cpu_normal_pricockroachdb.admission.wait_durations.elastic_cpu.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kvcockroachdb.admission.wait.durations.kv.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kvcockroachdb.admission.wait_durations.kv.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_high_pricockroachdb.admission.wait_durations.kv.high_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_locking_normal_pricockroachdb.admission.wait_durations.kv.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_normal_pricockroachdb.admission.wait_durations.kv.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_storescockroachdb.admission.wait_durations.kv_stores.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_storescockroachdb.admission.wait.durations.kv_stores.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_stores_high_pricockroachdb.admission.wait_durations.kv_stores.high_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_stores_locking_normal_pricockroachdb.admission.wait_durations.kv_stores.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_kv_stores_normal_pricockroachdb.admission.wait_durations.kv_stores.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_kv_responsecockroachdb.admission.wait.durations.sql_kv.response.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_kv_responsecockroachdb.admission.wait_durations.sql_kv_response.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_kv_response_locking_normal_pricockroachdb.admission.wait_durations.sql_kv_response.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_kv_response_normal_pricockroachdb.admission.wait_durations.sql_kv_response.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_leaf_startcockroachdb.admission.wait_durations.sql_leaf_start.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_leaf_startcockroachdb.admission.wait.durations.sql.leaf.start.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_leaf_start_locking_normal_pricockroachdb.admission.wait_durations.sql_leaf_start.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_leaf_start_normal_pricockroachdb.admission.wait_durations.sql_leaf_start.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_root_startcockroachdb.admission.wait_durations.sql_root_start.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_root_start_locking_normal_pricockroachdb.admission.wait_durations.sql_root_start.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_root_start_normal_pricockroachdb.admission.wait_durations.sql_root_start.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_sql_responsecockroachdb.admission.wait.durations.sql_sql.response.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_sql_responsecockroachdb.admission.wait.queue.length.sql_sql.responseWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_sql_responsecockroachdb.admission.wait_durations.sql_sql_response.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_sql_response_locking_normal_pricockroachdb.admission.wait_durations.sql_sql_response.locking_normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_durations_sql_sql_response_normal_pricockroachdb.admission.wait_durations.sql_sql_response.normal_pri.countWait time durations for requests that waitedcockroachdb
admission_wait_queue_length_elastic_cpucockroachdb.admission.wait_queue_length.elastic_cpuLength of wait queuecockroachdb
admission_wait_queue_length_elastic_cpu_bulk_normal_pricockroachdb.admission.wait_queue_length.elastic_cpu.bulk_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_elastic_cpu_normal_pricockroachdb.admission.wait_queue_length.elastic_cpu.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_kvcockroachdb.admission.wait_queue_length.kvLength of wait queuecockroachdb
admission_wait_queue_length_kvcockroachdb.admission.wait.queue.length.kvLength of wait queuecockroachdb
admission_wait_queue_length_kv_high_pricockroachdb.admission.wait_queue_length.kv.high_priLength of wait queuecockroachdb
admission_wait_queue_length_kv_locking_normal_pricockroachdb.admission.wait_queue_length.kv.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_kv_normal_pricockroachdb.admission.wait_queue_length.kv.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_kv_storescockroachdb.admission.wait.queue.length.kv_storesLength of wait queuecockroachdb
admission_wait_queue_length_kv_storescockroachdb.admission.wait_queue_length.kv_storesLength of wait queuecockroachdb
admission_wait_queue_length_kv_stores_high_pricockroachdb.admission.wait_queue_length.kv_stores.high_priLength of wait queuecockroachdb
admission_wait_queue_length_kv_stores_locking_normal_pricockroachdb.admission.wait_queue_length.kv_stores.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_kv_stores_normal_pricockroachdb.admission.wait_queue_length.kv_stores.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_kv_responsecockroachdb.admission.wait_queue_length.sql_kv_responseLength of wait queuecockroachdb
admission_wait_queue_length_sql_kv_responsecockroachdb.admission.wait.queue.length.sql_kv.responseLength of wait queuecockroachdb
admission_wait_queue_length_sql_kv_response_locking_normal_pricockroachdb.admission.wait_queue_length.sql_kv_response.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_kv_response_normal_pricockroachdb.admission.wait_queue_length.sql_kv_response.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_leaf_startcockroachdb.admission.wait.queue.length.sql.leaf.startLength of wait queuecockroachdb
admission_wait_queue_length_sql_leaf_startcockroachdb.admission.wait_queue_length.sql_leaf_startLength of wait queuecockroachdb
admission_wait_queue_length_sql_leaf_start_locking_normal_pricockroachdb.admission.wait_queue_length.sql_leaf_start.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_leaf_start_normal_pricockroachdb.admission.wait_queue_length.sql_leaf_start.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_root_startcockroachdb.admission.wait_queue_length.sql_root_startLength of wait queuecockroachdb
admission_wait_queue_length_sql_root_start_locking_normal_pricockroachdb.admission.wait_queue_length.sql_root_start.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_root_start_normal_pricockroachdb.admission.wait_queue_length.sql_root_start.normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_sql_responsecockroachdb.admission.wait_queue_length.sql_sql_responseLength of wait queuecockroachdb
admission_wait_queue_length_sql_sql_response_locking_normal_pricockroachdb.admission.wait_queue_length.sql_sql_response.locking_normal_priLength of wait queuecockroachdb
admission_wait_queue_length_sql_sql_response_normal_pricockroachdb.admission.wait_queue_length.sql_sql_response.normal_priLength of wait queuecockroachdb
backup_last_failed_time_kms_inaccessiblecockroachdb.backup.last_failed_time.kms_inaccessibleThe unix timestamp of the most recent failure of backup due to errKMSInaccessible by a backup specified as maintaining this metriccockroachdb
batch_requests_bytescockroachdb.batch_requests.bytes.countTotal byte count of batch requests processedcockroachdb
batch_requests_cross_region_bytescockroachdb.batch_requests.cross_region.bytes.countTotal byte count of batch requests processed cross region when region tiers are configuredcockroachdb
batch_requests_cross_zone_bytescockroachdb.batch_requests.cross_zone.bytes.countTotal byte count of batch requests processed cross zone within the same region when region and zone tiers are configured. However, if the region tiers are not configured, this count may also include batch data sent between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
batch_responses_bytescockroachdb.batch_responses.bytes.countTotal byte count of batch responses receivedcockroachdb
batch_responses_cross_region_bytescockroachdb.batch_responses.cross_region.bytes.countTotal byte count of batch responses received cross region when region tiers are configuredcockroachdb
batch_responses_cross_zone_bytescockroachdb.batch_responses.cross_zone.bytes.countTotal byte count of batch responses received cross zone within the same region when region and zone tiers are configured. However, if the region tiers are not configured, this count may also include batch data received between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
build_timestampcockroachdb.build.timestampBuild informationcockroachdb
capacity_availablecockroachdb.capacity.availableAvailable storage capacitycockroachdb
capacity_reservedcockroachdb.capacity.reservedCapacity reserved for snapshotscockroachdb
capacity_usedcockroachdb.capacity.usedUsed storage capacitycockroachdb
changefeed_admit_latencycockroachdb.changefeed.admit.latency.countEvent admission latency: a difference between event MVCC timestamp and the time it was admitted into changefeed pipeline; Note: this metric includes the time spent waiting until event can be processed due to backpressure or time spent resolving schema descriptors. Also note, this metric excludes latency during backfillcockroachdb
changefeed_aggregator_progresscockroachdb.changefeed.aggregator_progressThe earliest timestamp up to which any aggregator is guaranteed to have emitted all values forcockroachdb
changefeed_backfill_countcockroachdb.changefeed.backfill_countNumber of changefeeds currently executing backfillcockroachdb
changefeed_backfill_pending_rangescockroachdb.changefeed.backfill.pending.rangesNumber of ranges in an ongoing backfill that are yet to be fully emittedcockroachdb
changefeed_batch_reduction_countcockroachdb.changefeed.batch_reduction_countNumber of times a changefeed aggregator node attempted to reduce the size of message batches it emitted to the sinkcockroachdb
changefeed_buffer_entries_allocated_memcockroachdb.changefeed.buffer_entries.allocated_memCurrent quota pool memory allocationcockroachdb
changefeed_buffer_entries_flushcockroachdb.changefeed.buffer_entries.flush.countNumber of flush elements added to the buffercockroachdb
changefeed_buffer_entries_incockroachdb.changefeed.buffer_entries.in.countTotal entries entering the buffer between raft and changefeed sinkscockroachdb
changefeed_buffer_entries_kvcockroachdb.changefeed.buffer_entries.kv.countNumber of kv elements added to the buffercockroachdb
changefeed_buffer_entries_mem_acquiredcockroachdb.changefeed.buffer_entries_mem.acquired.countTotal amount of memory acquired for entries as they enter the systemcockroachdb
changefeed_buffer_entries_mem_releasedcockroachdb.changefeed.buffer_entries_mem.released.countTotal amount of memory released by the entries after they have been emittedcockroachdb
changefeed_buffer_entries_outcockroachdb.changefeed.buffer_entries.out.countTotal entries leaving the buffer between raft and changefeed sinkscockroachdb
changefeed_buffer_entries_releasedcockroachdb.changefeed.buffer_entries.released.countTotal entries processed, emitted and acknowledged by the sinkscockroachdb
changefeed_buffer_entries_resolvedcockroachdb.changefeed.buffer_entries.resolved.countNumber of resolved elements added to the buffercockroachdb
changefeed_checkpoint_hist_nanoscockroachdb.changefeed.checkpoint_hist_nanos.countTime spent checkpointing changefeed progresscockroachdb
changefeed_checkpoint_progresscockroachdb.changefeed.checkpoint_progressThe earliest timestamp of any changefeed’s persisted checkpoint (values prior to this timestamp will never need to be re-emitted)cockroachdb
changefeed_cloudstorage_buffered_bytescockroachdb.changefeed.cloudstorage_buffered_bytesThe number of bytes buffered in cloudstorage sink files which have not been emitted yetcockroachdb
changefeed_commit_latencycockroachdb.changefeed.commit.latency.countEvent commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink. If the sink batches events, then the difference between the oldest event in the batch and acknowledgement is recorded; Excludes latency during backfillcockroachdb
changefeed_emitted_bytescockroachdb.changefeed.emitted_bytes.countBytes emitted by all feedscockroachdb
changefeed_emitted_bytescockroachdb.changefeed.emitted_bytesBytes emitted by all feedscockroachdb
changefeed_emitted_messagescockroachdb.changefeed.emitted_messagesMessages emitted by all feedscockroachdb
changefeed_emitted_messagescockroachdb.changefeed.emitted.messages.countMessages emitted by all feedscockroachdb
changefeed_error_retriescockroachdb.changefeed.error.retries.countTotal retryable errors encountered by all changefeedscockroachdb
changefeed_error_retriescockroachdb.changefeed.error_retriesTotal retryable errors encountered by all changefeedscockroachdb
changefeed_failurescockroachdb.changefeed.failures.countTotal number of changefeed jobs which have failedcockroachdb
changefeed_filtered_messagescockroachdb.changefeed.filtered_messages.countMessages filtered out by all feeds. This count does not include the number of messages that may be filtered due to the range constraints.cockroachdb
changefeed_flush_hist_nanoscockroachdb.changefeed.flush_hist_nanos.countTime spent flushing messages across all changefeedscockroachdb
changefeed_flushed_bytescockroachdb.changefeed.flushed_bytes.countBytes emitted by all feeds; maybe different from changefeed.emitted_bytes when compression is enabledcockroachdb
changefeed_flushescockroachdb.changefeed.flushes.countTotal flushes across all feedscockroachdb
changefeed_forwarded_resolved_messagescockroachdb.changefeed.forwarded_resolved_messages.countResolved timestamps forwarded from the change aggregator to the change frontiercockroachdb
changefeed_frontier_updatescockroachdb.changefeed.frontier_updates.countNumber of change frontier updates across all feedscockroachdb
changefeed_lagging_rangescockroachdb.changefeed.lagging_rangesThe number of ranges considered to be lagging behindcockroachdb
changefeed_max_behind_nanoscockroachdb.changefeed.max_behind_nanos(Deprecated in favor of checkpoint_progress) The most any changefeed’s persisted checkpoint is behind the presentcockroachdb
changefeed_max_behind_nanoscockroachdb.changefeed.max.behind.nanos(Deprecated in favor of checkpoint_progress) The most any changefeed’s persisted checkpoint is behind the presentcockroachdb
changefeed_message_size_histcockroachdb.changefeed.message.size.hist.countMessage size histogramcockroachdb
changefeed_message_size_histcockroachdb.changefeed.message_size_hist.countMessage size histogramcockroachdb
changefeed_nprocs_consume_event_nanoscockroachdb.changefeed.nprocs_consume_event_nanos.countTotal time spent waiting to add an event to the parallel consumercockroachdb
changefeed_nprocs_flush_nanoscockroachdb.changefeed.nprocs_flush_nanos.countTotal time spent idle waiting for the parallel consumer to flushcockroachdb
changefeed_parallel_io_queue_nanoscockroachdb.changefeed.parallel_io_queue_nanos.countTime that outgoing requests to the sink spend waiting in a queue due to in-flight requests with conflicting keyscockroachdb
changefeed_runningcockroachdb.changefeed.runningNumber of currently running changefeeds, including sinklesscockroachdb
changefeed_schema_registry_registrationscockroachdb.changefeed.schema_registry.registrations.countNumber of registration attempts with the schema registrycockroachdb
changefeed_schemafeed_table_history_scanscockroachdb.changefeed.schemafeed.table_history_scans.countThe number of table history scans during pollingcockroachdb
changefeed_sink_batch_hist_nanoscockroachdb.changefeed.sink_batch_hist_nanos.countTime spent batched in the sink buffer before being flushed and acknowledgedcockroachdb
changefeed_sink_io_inflightcockroachdb.changefeed.sink_io_inflightThe number of keys currently inflight as IO requests being sent to the sinkcockroachdb
changefeed_size_based_flushescockroachdb.changefeed.size_based_flushes.countTotal size based flushes across all feedscockroachdb
clock_offset_meannanoscockroachdb.clock.offset.meannanosMean clock offset with other nodescockroachdb
clock_offset_stddevnanoscockroachdb.clock.offset.stddevnanosStddev clock offset with other nodescockroachdb
cloud_read_bytescockroachdb.cloud.read_bytes.countBytes read from all cloud operationscockroachdb
cloud_write_bytescockroachdb.cloud.write_bytes.countBytes written by all cloud operationscockroachdb
cluster_preserve_downgrade_option_last_updatedcockroachdb.cluster.preserve_downgrade_option.last_updatedUnix timestamp of last updated time for cluster.preserve_downgrade_optioncockroachdb
distsender_batch_requests_cross_region_bytescockroachdb.distsender.batch_requests.cross_region.bytes.countTotal byte count of replica-addressed batch requests processed cross region when region tiers are configuredcockroachdb
distsender_batch_requests_cross_zone_bytescockroachdb.distsender.batch_requests.cross_zone.bytes.countTotal byte count of replica-addressed batch requests processed cross zone within the same region when region and zone tiers are configured. However, if the region tiers are not configured, this count may also include batch data sent between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
distsender_batch_requests_replica_addressed_bytescockroachdb.distsender.batch_requests.replica_addressed.bytes.countTotal byte count of replica-addressed batch requests processedcockroachdb
distsender_batch_responses_cross_region_bytescockroachdb.distsender.batch_responses.cross_region.bytes.countTotal byte count of replica-addressed batch responses received cross region when region tiers are configuredcockroachdb
distsender_batch_responses_cross_zone_bytescockroachdb.distsender.batch_responses.cross_zone.bytes.countTotal byte count of replica-addressed batch responses received cross zone within the same region when region and zone tiers are configured. However, if the region tiers are not configured, this count may also include batch data received between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
distsender_batch_responses_replica_addressed_bytescockroachdb.distsender.batch_responses.replica_addressed.bytes.countTotal byte count of replica-addressed batch responses receivedcockroachdb
distsender_batchescockroachdb.distsender.batches.countNumber of batches processedcockroachdb
distsender_batches_async_sentcockroachdb.distsender.batches.async.sent.countNumber of partial batches sent asynchronouslycockroachdb
distsender_batches_async_throttledcockroachdb.distsender.batches.async.throttled.countNumber of partial batches not sent asynchronously due to throttlingcockroachdb
distsender_batches_partialcockroachdb.distsender.batches.partial.countNumber of partial batches processed after being divided on range boundariescockroachdb
distsender_errors_inleasetransferbackoffscockroachdb.distsender.errors.inleasetransferbackoffs.countNumber of times backed off due to NotLeaseHolderErrors during lease transfercockroachdb
distsender_errors_notleaseholdercockroachdb.distsender.errors.notleaseholder.countNumber of NotLeaseHolderErrors encountered from replica-addressed RPCscockroachdb
distsender_rangefeed_catchup_rangescockroachdb.distsender.rangefeed.catchup_rangesNumber of ranges in catchup mode This counts the number of ranges with an active rangefeed that are performing catchup scan.cockroachdb
distsender_rangefeed_error_catchup_rangescockroachdb.distsender.rangefeed.error_catchup_ranges.countNumber of ranges in catchup mode which experienced an errorcockroachdb
distsender_rangefeed_restart_rangescockroachdb.distsender.rangefeed.restart_ranges.countNumber of ranges that were restarted due to transient errorscockroachdb
distsender_rangefeed_retry_logical_ops_missingcockroachdb.distsender.rangefeed.retry.logical_ops_missing.countNumber of ranges that encountered retryable LOGICAL_OPS_MISSING errorcockroachdb
distsender_rangefeed_retry_no_leaseholdercockroachdb.distsender.rangefeed.retry.no_leaseholder.countNumber of ranges that encountered retryable NO_LEASEHOLDER errorcockroachdb
distsender_rangefeed_retry_node_not_foundcockroachdb.distsender.rangefeed.retry.node_not_found.countNumber of ranges that encountered retryable node not found errorcockroachdb
distsender_rangefeed_retry_raft_snapshotcockroachdb.distsender.rangefeed.retry.raft_snapshot.countNumber of ranges that encountered retryable RAFT_SNAPSHOT errorcockroachdb
distsender_rangefeed_retry_range_key_mismatchcockroachdb.distsender.rangefeed.retry.range_key_mismatch.countNumber of ranges that encountered retryable range key mismatch errorcockroachdb
distsender_rangefeed_retry_range_mergedcockroachdb.distsender.rangefeed.retry.range_merged.countNumber of ranges that encountered retryable RANGE_MERGED errorcockroachdb
distsender_rangefeed_retry_range_not_foundcockroachdb.distsender.rangefeed.retry.range_not_found.countNumber of ranges that encountered retryable range not found errorcockroachdb
distsender_rangefeed_retry_range_splitcockroachdb.distsender.rangefeed.retry.range_split.countNumber of ranges that encountered retryable RANGE_SPLIT errorcockroachdb
distsender_rangefeed_retry_rangefeed_closedcockroachdb.distsender.rangefeed.retry.rangefeed_closed.countNumber of ranges that encountered retryable RANGEFEED_CLOSED errorcockroachdb
distsender_rangefeed_retry_replica_removedcockroachdb.distsender.rangefeed.retry.replica_removed.countNumber of ranges that encountered retryable REPLICA_REMOVED errorcockroachdb
distsender_rangefeed_retry_sendcockroachdb.distsender.rangefeed.retry.send.countNumber of ranges that encountered retryable send errorcockroachdb
distsender_rangefeed_retry_slow_consumercockroachdb.distsender.rangefeed.retry.slow_consumer.countNumber of ranges that encountered retryable SLOW_CONSUMER errorcockroachdb
distsender_rangefeed_retry_store_not_foundcockroachdb.distsender.rangefeed.retry.store_not_found.countNumber of ranges that encountered retryable store not found errorcockroachdb
distsender_rangefeed_total_rangescockroachdb.distsender.rangefeed.total_rangesNumber of ranges executing rangefeed This counts the number of ranges with an active rangefeed.cockroachdb
distsender_rangelookupscockroachdb.distsender.rangelookups.countNumber of range lookupscockroachdb
distsender_rpc_addsstable_sentcockroachdb.distsender.rpc.addsstable.sent.countNumber of AddSSTable requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminchangereplicas_sentcockroachdb.distsender.rpc.adminchangereplicas.sent.countNumber of AdminChangeReplicas requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminmerge_sentcockroachdb.distsender.rpc.adminmerge.sent.countNumber of AdminMerge requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminrelocaterange_sentcockroachdb.distsender.rpc.adminrelocaterange.sent.countNumber of AdminRelocateRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminscatter_sentcockroachdb.distsender.rpc.adminscatter.sent.countNumber of AdminScatter requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminsplit_sentcockroachdb.distsender.rpc.adminsplit.sent.countNumber of AdminSplit requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_admintransferlease_sentcockroachdb.distsender.rpc.admintransferlease.sent.countNumber of AdminTransferLease requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminunsplit_sentcockroachdb.distsender.rpc.adminunsplit.sent.countNumber of AdminUnsplit requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_adminverifyprotectedtimestamp_sentcockroachdb.distsender.rpc.adminverifyprotectedtimestamp.sent.countNumber of AdminVerifyProtectedTimestamp requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_barrier_sentcockroachdb.distsender.rpc.barrier.sent.countNumber of Barrier requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_checkconsistency_sentcockroachdb.distsender.rpc.checkconsistency.sent.countNumber of CheckConsistency requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_clearrange_sentcockroachdb.distsender.rpc.clearrange.sent.countNumber of ClearRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_computechecksum_sentcockroachdb.distsender.rpc.computechecksum.sent.countNumber of ComputeChecksum requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_conditionalput_sentcockroachdb.distsender.rpc.conditionalput.sent.countNumber of ConditionalPut requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_delete_sentcockroachdb.distsender.rpc.delete.sent.countNumber of Delete requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_deleterange_sentcockroachdb.distsender.rpc.deleterange.sent.countNumber of DeleteRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_endtxn_sentcockroachdb.distsender.rpc.endtxn.sent.countNumber of EndTxn requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_err_ambiguousresulterrtypecockroachdb.distsender.rpc.err.ambiguousresulterrtype.countNumber of AmbiguousResultErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_batchtimestampbeforegcerrtypecockroachdb.distsender.rpc.err.batchtimestampbeforegcerrtype.countNumber of BatchTimestampBeforeGCErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_communicationerrtypecockroachdb.distsender.rpc.err.communicationerrtype.countNumber of CommunicationErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_conditionfailederrtypecockroachdb.distsender.rpc.err.conditionfailederrtype.countNumber of ConditionFailedErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_indeterminatecommiterrtypecockroachdb.distsender.rpc.err.indeterminatecommiterrtype.countNumber of IndeterminateCommitErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_integeroverflowerrtypecockroachdb.distsender.rpc.err.integeroverflowerrtype.countNumber of IntegerOverflowErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_intentmissingerrtypecockroachdb.distsender.rpc.err.intentmissingerrtype.countNumber of IntentMissingErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_internalerrtypecockroachdb.distsender.rpc.err.internalerrtype.countNumber of InternalErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_invalidleaseerrtypecockroachdb.distsender.rpc.err.invalidleaseerrtype.countNumber of InvalidLeaseErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_leaserejectederrtypecockroachdb.distsender.rpc.err.leaserejectederrtype.countNumber of LeaseRejectedErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_lockconflicterrtypecockroachdb.distsender.rpc.err.lockconflicterrtype.countNumber of LockConflictErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_mergeinprogresserrtypecockroachdb.distsender.rpc.err.mergeinprogresserrtype.countNumber of MergeInProgressErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_mintimestampboundunsatisfiableerrtypecockroachdb.distsender.rpc.err.mintimestampboundunsatisfiableerrtype.countNumber of MinTimestampBoundUnsatisfiableErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_mvcchistorymutationerrtypecockroachdb.distsender.rpc.err.mvcchistorymutationerrtype.countNumber of MVCCHistoryMutationErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_nodeunavailableerrtypecockroachdb.distsender.rpc.err.nodeunavailableerrtype.countNumber of NodeUnavailableErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_notleaseholdererrtypecockroachdb.distsender.rpc.err.notleaseholdererrtype.countNumber of NotLeaseHolderErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_oprequirestxnerrtypecockroachdb.distsender.rpc.err.oprequirestxnerrtype.countNumber of OpRequiresTxnErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_optimisticevalconflictserrtypecockroachdb.distsender.rpc.err.optimisticevalconflictserrtype.countNumber of OptimisticEvalConflictsErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_raftgroupdeletederrtypecockroachdb.distsender.rpc.err.raftgroupdeletederrtype.countNumber of RaftGroupDeletedErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_rangefeedretryerrtypecockroachdb.distsender.rpc.err.rangefeedretryerrtype.countNumber of RangeFeedRetryErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_rangekeymismatcherrtypecockroachdb.distsender.rpc.err.rangekeymismatcherrtype.countNumber of RangeKeyMismatchErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_rangenotfounderrtypecockroachdb.distsender.rpc.err.rangenotfounderrtype.countNumber of RangeNotFoundErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_readwithinuncertaintyintervalerrtypecockroachdb.distsender.rpc.err.readwithinuncertaintyintervalerrtype.countNumber of ReadWithinUncertaintyIntervalErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_refreshfailederrtypecockroachdb.distsender.rpc.err.refreshfailederrtype.countNumber of RefreshFailedErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_replicacorruptionerrtypecockroachdb.distsender.rpc.err.replicacorruptionerrtype.countNumber of ReplicaCorruptionErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_replicatooolderrtypecockroachdb.distsender.rpc.err.replicatooolderrtype.countNumber of ReplicaTooOldErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_storenotfounderrtypecockroachdb.distsender.rpc.err.storenotfounderrtype.countNumber of StoreNotFoundErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_transactionabortederrtypecockroachdb.distsender.rpc.err.transactionabortederrtype.countNumber of TransactionAbortedErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_transactionpusherrtypecockroachdb.distsender.rpc.err.transactionpusherrtype.countNumber of TransactionPushErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_transactionretryerrtypecockroachdb.distsender.rpc.err.transactionretryerrtype.countNumber of TransactionRetryErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_transactionretrywithprotorefresherrtypecockroachdb.distsender.rpc.err.transactionretrywithprotorefresherrtype.countNumber of TransactionRetryWithProtoRefreshErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_transactionstatuserrtypecockroachdb.distsender.rpc.err.transactionstatuserrtype.countNumber of TransactionStatusErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_txnalreadyencounterederrtypecockroachdb.distsender.rpc.err.txnalreadyencounterederrtype.countNumber of TxnAlreadyEncounteredErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_unsupportedrequesterrtypecockroachdb.distsender.rpc.err.unsupportedrequesterrtype.countNumber of UnsupportedRequestErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_writeintenterrtypecockroachdb.distsender.rpc.err.writeintenterrtype.countNumber of WriteIntentErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_err_writetooolderrtypecockroachdb.distsender.rpc.err.writetooolderrtype.countNumber of WriteTooOldErrType errors received replica-bound RPCs This counts how often error of the specified type was received back from replicas as part of executing possibly range-spanning requests. Failures to reach the target replica will be accounted for as ‘roachpb.CommunicationErrType’ and unclassified errors as ‘roachpb.InternalErrType’.cockroachdb
distsender_rpc_export_sentcockroachdb.distsender.rpc.export.sent.countNumber of Export requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_gc_sentcockroachdb.distsender.rpc.gc.sent.countNumber of GC requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_get_sentcockroachdb.distsender.rpc.get.sent.countNumber of Get requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_heartbeattxn_sentcockroachdb.distsender.rpc.heartbeattxn.sent.countNumber of HeartbeatTxn requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_increment_sentcockroachdb.distsender.rpc.increment.sent.countNumber of Increment requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_initput_sentcockroachdb.distsender.rpc.initput.sent.countNumber of InitPut requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_isspanempty_sentcockroachdb.distsender.rpc.isspanempty.sent.countNumber of IsSpanEmpty requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_leaseinfo_sentcockroachdb.distsender.rpc.leaseinfo.sent.countNumber of LeaseInfo requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_merge_sentcockroachdb.distsender.rpc.merge.sent.countNumber of Merge requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_migrate_sentcockroachdb.distsender.rpc.migrate.sent.countNumber of Migrate requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_probe_sentcockroachdb.distsender.rpc.probe.sent.countNumber of Probe requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_pushtxn_sentcockroachdb.distsender.rpc.pushtxn.sent.countNumber of PushTxn requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_put_sentcockroachdb.distsender.rpc.put.sent.countNumber of Put requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_queryintent_sentcockroachdb.distsender.rpc.queryintent.sent.countNumber of QueryIntent requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_querylocks_sentcockroachdb.distsender.rpc.querylocks.sent.countNumber of QueryLocks requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_queryresolvedtimestamp_sentcockroachdb.distsender.rpc.queryresolvedtimestamp.sent.countNumber of QueryResolvedTimestamp requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_querytxn_sentcockroachdb.distsender.rpc.querytxn.sent.countNumber of QueryTxn requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_rangestats_sentcockroachdb.distsender.rpc.rangestats.sent.countNumber of RangeStats requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_recomputestats_sentcockroachdb.distsender.rpc.recomputestats.sent.countNumber of RecomputeStats requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_recovertxn_sentcockroachdb.distsender.rpc.recovertxn.sent.countNumber of RecoverTxn requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_refresh_sentcockroachdb.distsender.rpc.refresh.sent.countNumber of Refresh requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_refreshrange_sentcockroachdb.distsender.rpc.refreshrange.sent.countNumber of RefreshRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_requestlease_sentcockroachdb.distsender.rpc.requestlease.sent.countNumber of RequestLease requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_resolveintent_sentcockroachdb.distsender.rpc.resolveintent.sent.countNumber of ResolveIntent requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_resolveintentrange_sentcockroachdb.distsender.rpc.resolveintentrange.sent.countNumber of ResolveIntentRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_reversescan_sentcockroachdb.distsender.rpc.reversescan.sent.countNumber of ReverseScan requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_revertrange_sentcockroachdb.distsender.rpc.revertrange.sent.countNumber of RevertRange requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_scan_sentcockroachdb.distsender.rpc.scan.sent.countNumber of Scan requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_sentcockroachdb.distsender.rpc.sent.countNumber of replica-addressed RPCs sentcockroachdb
distsender_rpc_sent_localcockroachdb.distsender.rpc.sent.local.countNumber of replica-addressed RPCs sent through the local-server optimizationcockroachdb
distsender_rpc_sent_nextreplicaerrorcockroachdb.distsender.rpc.sent.nextreplicaerror.countNumber of replica-addressed RPCs sent due to per-replica errorscockroachdb
distsender_rpc_subsume_sentcockroachdb.distsender.rpc.subsume.sent.countNumber of Subsume requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_transferlease_sentcockroachdb.distsender.rpc.transferlease.sent.countNumber of TransferLease requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_truncatelog_sentcockroachdb.distsender.rpc.truncatelog.sent.countNumber of TruncateLog requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
distsender_rpc_writebatch_sentcockroachdb.distsender.rpc.writebatch.sent.countNumber of WriteBatch requests processed. This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.cockroachdb
exec_errorcockroachdb.exec.error.countNumber of batch KV requests that failed to execute on this node. This count excludes transaction restart/abort errors. However, it will include other errors expected during normal operation, such as ConditionFailedError. This metric is thus not an indicator of KV health.cockroachdb
exec_latencycockroachdb.exec.latency.countLatency of batch KV requests (including errors) executed on this node. This measures requests already addressed to a single replica, from the moment at which they arrive at the internal gRPC endpoint to the moment at which the response (or an error) is returned. This latency includes in particular commit waits, conflict resolution and replication, and end-users can easily produce high measurements via long-running transactions that conflict with foreground traffic. This metric thus does not provide a good signal for understanding the health of the KV layer.cockroachdb
exec_successcockroachdb.exec.success.countNumber of batch KV requests executed successfully on this node. A request is considered to have executed ‘successfully’ if it either returns a result or a transaction restart/abort error.cockroachdb
follower_reads_success_countcockroachdb.follower_reads.success_count.countNumber of reads successfully processed by any replicacockroachdb
gcbytesagecockroachdb.gcbytesageCumulative age of non-live datacockroachdb
gossip_bytes_receivedcockroachdb.gossip.bytes.received.countNumber of received gossip bytescockroachdb
gossip_bytes_sentcockroachdb.gossip.bytes.sent.countNumber of sent gossip bytescockroachdb
gossip_connections_incomingcockroachdb.gossip.connections.incomingNumber of active incoming gossip connectionscockroachdb
gossip_connections_outgoingcockroachdb.gossip.connections.outgoingNumber of active outgoing gossip connectionscockroachdb
gossip_connections_refusedcockroachdb.gossip.connections.refused.countNumber of refused incoming gossip connectionscockroachdb
gossip_infos_receivedcockroachdb.gossip.infos.received.countNumber of received gossip Info objectscockroachdb
gossip_infos_sentcockroachdb.gossip.infos.sent.countNumber of sent gossip Info objectscockroachdb
intentagecockroachdb.intentageCumulative age of lockscockroachdb
intentbytescockroachdb.intentbytesNumber of bytes in intent KV pairscockroachdb
intentcountcockroachdb.intentcountCount of intent keyscockroachdb
intentresolver_async_throttledcockroachdb.intentresolver.async.throttledNumber of intent resolution attempts not run asynchronously due to throttlingcockroachdb
intentresolver_async_throttledcockroachdb.intentresolver.async.throttled.countNumber of intent resolution attempts not run asynchronously due to throttlingcockroachdb
intentresolver_finalized_txns_failedcockroachdb.intentresolver.finalized_txns.failedNumber of finalized transaction cleanup failures. Transaction cleanup refers to the process of resolving all of a transactions intents and then garbage collecting its transaction record.cockroachdb
intentresolver_finalized_txns_failedcockroachdb.intentresolver.finalized_txns.failed.countNumber of finalized transaction cleanup failures. Transaction cleanup refers to the process of resolving all of a transactions intents and then garbage collecting its transaction record.cockroachdb
intentresolver_intents_failedcockroachdb.intentresolver.intents.failedNumber of intent resolution failures. The unit of measurement is a single intent, so if a batch of intent resolution requests fails, the metric will be incremented for each request in the batch.cockroachdb
intentresolver_intents_failedcockroachdb.intentresolver.intents.failed.countNumber of intent resolution failures. The unit of measurement is a single intent, so if a batch of intent resolution requests fails, the metric will be incremented for each request in the batch.cockroachdb
intents_abort_attemptscockroachdb.intents.abort_attemptsCount of (point or range) non-poisoning intent abort evaluation attemptscockroachdb
intents_abort_attemptscockroachdb.intents.abort_attempts.countCount of (point or range) non-poisoning intent abort evaluation attemptscockroachdb
intents_poison_attemptscockroachdb.intents.poison_attempts.countCount of (point or range) poisoning intent abort evaluation attemptscockroachdb
intents_poison_attemptscockroachdb.intents.poison_attemptsCount of (point or range) poisoning intent abort evaluation attemptscockroachdb
intents_resolve_attemptscockroachdb.intents.resolve_attemptsCount of (point or range) intent commit evaluation attemptscockroachdb
intents_resolve_attemptscockroachdb.intents.resolve_attempts.countCount of (point or range) intent commit evaluation attemptscockroachdb
jobs_adopt_iterationscockroachdb.jobs.adopt_iterations.countnumber of job-adopt iterations performed by the registrycockroachdb
jobs_auto_config_env_runner_currently_idlecockroachdb.jobs.auto_config_env_runner.currently_idleNumber of auto_config_env_runner jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_config_env_runner_currently_pausedcockroachdb.jobs.auto_config_env_runner.currently_pausedNumber of auto_config_env_runner jobs currently considered Pausedcockroachdb
jobs_auto_config_env_runner_currently_runningcockroachdb.jobs.auto_config_env_runner.currently_runningNumber of auto_config_env_runner jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_config_env_runner_expired_pts_recordscockroachdb.jobs.auto_config_env_runner.expired_pts_records.countNumber of expired protected timestamp records owned by auto_config_env_runner jobscockroachdb
jobs_auto_config_env_runner_fail_or_cancel_completedcockroachdb.jobs.auto_config_env_runner.fail_or_cancel_completed.countNumber of auto_config_env_runner jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_config_env_runner_fail_or_cancel_failedcockroachdb.jobs.auto_config_env_runner.fail_or_cancel_failed.countNumber of auto_config_env_runner jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_env_runner_fail_or_cancel_retry_errorcockroachdb.jobs.auto_config_env_runner.fail_or_cancel_retry_error.countNumber of auto_config_env_runner jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_env_runner_protected_age_seccockroachdb.jobs.auto_config_env_runner.protected_age_secThe age of the oldest PTS record protected by auto_config_env_runner jobscockroachdb
jobs_auto_config_env_runner_protected_record_countcockroachdb.jobs.auto_config_env_runner.protected_record_countNumber of protected timestamp records held by auto_config_env_runner jobscockroachdb
jobs_auto_config_env_runner_resume_completedcockroachdb.jobs.auto_config_env_runner.resume_completed.countNumber of auto_config_env_runner jobs which successfully resumed to completioncockroachdb
jobs_auto_config_env_runner_resume_failedcockroachdb.jobs.auto_config_env_runner.resume_failed.countNumber of auto_config_env_runner jobs which failed with a non-retriable errorcockroachdb
jobs_auto_config_env_runner_resume_retry_errorcockroachdb.jobs.auto_config_env_runner.resume_retry_error.countNumber of auto_config_env_runner jobs which failed with a retriable errorcockroachdb
jobs_auto_config_runner_currently_idlecockroachdb.jobs.auto_config_runner.currently_idleNumber of auto_config_runner jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_config_runner_currently_pausedcockroachdb.jobs.auto_config_runner.currently_pausedNumber of auto_config_runner jobs currently considered Pausedcockroachdb
jobs_auto_config_runner_currently_runningcockroachdb.jobs.auto_config_runner.currently_runningNumber of auto_config_runner jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_config_runner_expired_pts_recordscockroachdb.jobs.auto_config_runner.expired_pts_records.countNumber of expired protected timestamp records owned by auto_config_runner jobscockroachdb
jobs_auto_config_runner_fail_or_cancel_completedcockroachdb.jobs.auto_config_runner.fail_or_cancel_completed.countNumber of auto_config_runner jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_config_runner_fail_or_cancel_failedcockroachdb.jobs.auto_config_runner.fail_or_cancel_failed.countNumber of auto_config_runner jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_runner_fail_or_cancel_retry_errorcockroachdb.jobs.auto_config_runner.fail_or_cancel_retry_error.countNumber of auto_config_runner jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_runner_protected_age_seccockroachdb.jobs.auto_config_runner.protected_age_secThe age of the oldest PTS record protected by auto_config_runner jobscockroachdb
jobs_auto_config_runner_protected_record_countcockroachdb.jobs.auto_config_runner.protected_record_countNumber of protected timestamp records held by auto_config_runner jobscockroachdb
jobs_auto_config_runner_resume_completedcockroachdb.jobs.auto_config_runner.resume_completed.countNumber of auto_config_runner jobs which successfully resumed to completioncockroachdb
jobs_auto_config_runner_resume_failedcockroachdb.jobs.auto_config_runner.resume_failed.countNumber of auto_config_runner jobs which failed with a non-retriable errorcockroachdb
jobs_auto_config_runner_resume_retry_errorcockroachdb.jobs.auto_config_runner.resume_retry_error.countNumber of auto_config_runner jobs which failed with a retriable errorcockroachdb
jobs_auto_config_task_currently_idlecockroachdb.jobs.auto_config_task.currently_idleNumber of auto_config_task jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_config_task_currently_pausedcockroachdb.jobs.auto_config_task.currently_pausedNumber of auto_config_task jobs currently considered Pausedcockroachdb
jobs_auto_config_task_currently_runningcockroachdb.jobs.auto_config_task.currently_runningNumber of auto_config_task jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_config_task_expired_pts_recordscockroachdb.jobs.auto_config_task.expired_pts_records.countNumber of expired protected timestamp records owned by auto_config_task jobscockroachdb
jobs_auto_config_task_fail_or_cancel_completedcockroachdb.jobs.auto_config_task.fail_or_cancel_completed.countNumber of auto_config_task jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_config_task_fail_or_cancel_failedcockroachdb.jobs.auto_config_task.fail_or_cancel_failed.countNumber of auto_config_task jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_task_fail_or_cancel_retry_errorcockroachdb.jobs.auto_config_task.fail_or_cancel_retry_error.countNumber of auto_config_task jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_config_task_protected_age_seccockroachdb.jobs.auto_config_task.protected_age_secThe age of the oldest PTS record protected by auto_config_task jobscockroachdb
jobs_auto_config_task_protected_record_countcockroachdb.jobs.auto_config_task.protected_record_countNumber of protected timestamp records held by auto_config_task jobscockroachdb
jobs_auto_config_task_resume_completedcockroachdb.jobs.auto_config_task.resume_completed.countNumber of auto_config_task jobs which successfully resumed to completioncockroachdb
jobs_auto_config_task_resume_failedcockroachdb.jobs.auto_config_task.resume_failed.countNumber of auto_config_task jobs which failed with a non-retriable errorcockroachdb
jobs_auto_config_task_resume_retry_errorcockroachdb.jobs.auto_config_task.resume_retry_error.countNumber of auto_config_task jobs which failed with a retriable errorcockroachdb
jobs_auto_create_stats_currently_idlecockroachdb.jobs.auto_create_stats.currently_idleNumber of auto_create_stats jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_create_stats_currently_pausedcockroachdb.jobs.auto.create.stats.currently_pausedNumber of auto_create_stats jobs currently considered Pausedcockroachdb
jobs_auto_create_stats_currently_pausedcockroachdb.jobs.auto_create_stats.currently_pausedNumber of auto_create_stats jobs currently considered Pausedcockroachdb
jobs_auto_create_stats_currently_runningcockroachdb.jobs.auto_create_stats.currently_runningNumber of auto_create_stats jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_create_stats_currently_runningcockroachdb.jobs.auto.create.stats.currently_runningNumber of auto_create_stats jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_create_stats_expired_pts_recordscockroachdb.jobs.auto_create_stats.expired_pts_records.countNumber of expired protected timestamp records owned by auto_create_stats jobscockroachdb
jobs_auto_create_stats_fail_or_cancel_completedcockroachdb.jobs.auto_create_stats.fail_or_cancel_completed.countNumber of auto_create_stats jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_create_stats_fail_or_cancel_failedcockroachdb.jobs.auto_create_stats.fail_or_cancel_failed.countNumber of auto_create_stats jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_create_stats_fail_or_cancel_retry_errorcockroachdb.jobs.auto_create_stats.fail_or_cancel_retry_error.countNumber of auto_create_stats jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_create_stats_protected_age_seccockroachdb.jobs.auto_create_stats.protected_age_secThe age of the oldest PTS record protected by auto_create_stats jobscockroachdb
jobs_auto_create_stats_protected_record_countcockroachdb.jobs.auto_create_stats.protected_record_countNumber of protected timestamp records held by auto_create_stats jobscockroachdb
jobs_auto_create_stats_resume_completedcockroachdb.jobs.auto_create_stats.resume_completed.countNumber of auto_create_stats jobs which successfully resumed to completioncockroachdb
jobs_auto_create_stats_resume_failedcockroachdb.jobs.auto.create.stats.resume_failed.countNumber of auto_create_stats jobs which failed with a non-retriable errorcockroachdb
jobs_auto_create_stats_resume_failedcockroachdb.jobs.auto_create_stats.resume_failed.countNumber of auto_create_stats jobs which failed with a non-retriable errorcockroachdb
jobs_auto_create_stats_resume_retry_errorcockroachdb.jobs.auto_create_stats.resume_retry_error.countNumber of auto_create_stats jobs which failed with a retriable errorcockroachdb
jobs_auto_schema_telemetry_currently_idlecockroachdb.jobs.auto_schema_telemetry.currently_idleNumber of auto_schema_telemetry jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_schema_telemetry_currently_pausedcockroachdb.jobs.auto_schema_telemetry.currently_pausedNumber of auto_schema_telemetry jobs currently considered Pausedcockroachdb
jobs_auto_schema_telemetry_currently_runningcockroachdb.jobs.auto_schema_telemetry.currently_runningNumber of auto_schema_telemetry jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_schema_telemetry_expired_pts_recordscockroachdb.jobs.auto_schema_telemetry.expired_pts_records.countNumber of expired protected timestamp records owned by auto_schema_telemetry jobscockroachdb
jobs_auto_schema_telemetry_fail_or_cancel_completedcockroachdb.jobs.auto_schema_telemetry.fail_or_cancel_completed.countNumber of auto_schema_telemetry jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_schema_telemetry_fail_or_cancel_failedcockroachdb.jobs.auto_schema_telemetry.fail_or_cancel_failed.countNumber of auto_schema_telemetry jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_schema_telemetry_fail_or_cancel_retry_errorcockroachdb.jobs.auto_schema_telemetry.fail_or_cancel_retry_error.countNumber of auto_schema_telemetry jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_schema_telemetry_protected_age_seccockroachdb.jobs.auto_schema_telemetry.protected_age_secThe age of the oldest PTS record protected by auto_schema_telemetry jobscockroachdb
jobs_auto_schema_telemetry_protected_record_countcockroachdb.jobs.auto_schema_telemetry.protected_record_countNumber of protected timestamp records held by auto_schema_telemetry jobscockroachdb
jobs_auto_schema_telemetry_resume_completedcockroachdb.jobs.auto_schema_telemetry.resume_completed.countNumber of auto_schema_telemetry jobs which successfully resumed to completioncockroachdb
jobs_auto_schema_telemetry_resume_failedcockroachdb.jobs.auto_schema_telemetry.resume_failed.countNumber of auto_schema_telemetry jobs which failed with a non-retriable errorcockroachdb
jobs_auto_schema_telemetry_resume_retry_errorcockroachdb.jobs.auto_schema_telemetry.resume_retry_error.countNumber of auto_schema_telemetry jobs which failed with a retriable errorcockroachdb
jobs_auto_span_config_reconciliation_currently_idlecockroachdb.jobs.auto_span_config_reconciliation.currently_idleNumber of auto_span_config_reconciliation jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_span_config_reconciliation_currently_pausedcockroachdb.jobs.auto_span_config_reconciliation.currently_pausedNumber of auto_span_config_reconciliation jobs currently considered Pausedcockroachdb
jobs_auto_span_config_reconciliation_currently_runningcockroachdb.jobs.auto_span_config_reconciliation.currently_runningNumber of auto_span_config_reconciliation jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_span_config_reconciliation_expired_pts_recordscockroachdb.jobs.auto_span_config_reconciliation.expired_pts_records.countNumber of expired protected timestamp records owned by auto_span_config_reconciliation jobscockroachdb
jobs_auto_span_config_reconciliation_fail_or_cancel_completedcockroachdb.jobs.auto_span_config_reconciliation.fail_or_cancel_completed.countNumber of auto_span_config_reconciliation jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_span_config_reconciliation_fail_or_cancel_failedcockroachdb.jobs.auto_span_config_reconciliation.fail_or_cancel_failed.countNumber of auto_span_config_reconciliation jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_span_config_reconciliation_fail_or_cancel_retry_errorcockroachdb.jobs.auto_span_config_reconciliation.fail_or_cancel_retry_error.countNumber of auto_span_config_reconciliation jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_span_config_reconciliation_protected_age_seccockroachdb.jobs.auto_span_config_reconciliation.protected_age_secThe age of the oldest PTS record protected by auto_span_config_reconciliation jobscockroachdb
jobs_auto_span_config_reconciliation_protected_record_countcockroachdb.jobs.auto_span_config_reconciliation.protected_record_countNumber of protected timestamp records held by auto_span_config_reconciliation jobscockroachdb
jobs_auto_span_config_reconciliation_resume_completedcockroachdb.jobs.auto_span_config_reconciliation.resume_completed.countNumber of auto_span_config_reconciliation jobs which successfully resumed to completioncockroachdb
jobs_auto_span_config_reconciliation_resume_failedcockroachdb.jobs.auto_span_config_reconciliation.resume_failed.countNumber of auto_span_config_reconciliation jobs which failed with a non-retriable errorcockroachdb
jobs_auto_span_config_reconciliation_resume_retry_errorcockroachdb.jobs.auto_span_config_reconciliation.resume_retry_error.countNumber of auto_span_config_reconciliation jobs which failed with a retriable errorcockroachdb
jobs_auto_sql_stats_compaction_currently_idlecockroachdb.jobs.auto_sql_stats_compaction.currently_idleNumber of auto_sql_stats_compaction jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_sql_stats_compaction_currently_pausedcockroachdb.jobs.auto_sql_stats_compaction.currently_pausedNumber of auto_sql_stats_compaction jobs currently considered Pausedcockroachdb
jobs_auto_sql_stats_compaction_currently_runningcockroachdb.jobs.auto_sql_stats_compaction.currently_runningNumber of auto_sql_stats_compaction jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_sql_stats_compaction_expired_pts_recordscockroachdb.jobs.auto_sql_stats_compaction.expired_pts_records.countNumber of expired protected timestamp records owned by auto_sql_stats_compaction jobscockroachdb
jobs_auto_sql_stats_compaction_fail_or_cancel_completedcockroachdb.jobs.auto_sql_stats_compaction.fail_or_cancel_completed.countNumber of auto_sql_stats_compaction jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_sql_stats_compaction_fail_or_cancel_failedcockroachdb.jobs.auto_sql_stats_compaction.fail_or_cancel_failed.countNumber of auto_sql_stats_compaction jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_sql_stats_compaction_fail_or_cancel_retry_errorcockroachdb.jobs.auto_sql_stats_compaction.fail_or_cancel_retry_error.countNumber of auto_sql_stats_compaction jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_sql_stats_compaction_protected_age_seccockroachdb.jobs.auto_sql_stats_compaction.protected_age_secThe age of the oldest PTS record protected by auto_sql_stats_compaction jobscockroachdb
jobs_auto_sql_stats_compaction_protected_record_countcockroachdb.jobs.auto_sql_stats_compaction.protected_record_countNumber of protected timestamp records held by auto_sql_stats_compaction jobscockroachdb
jobs_auto_sql_stats_compaction_resume_completedcockroachdb.jobs.auto_sql_stats_compaction.resume_completed.countNumber of auto_sql_stats_compaction jobs which successfully resumed to completioncockroachdb
jobs_auto_sql_stats_compaction_resume_failedcockroachdb.jobs.auto_sql_stats_compaction.resume_failed.countNumber of auto_sql_stats_compaction jobs which failed with a non-retriable errorcockroachdb
jobs_auto_sql_stats_compaction_resume_retry_errorcockroachdb.jobs.auto_sql_stats_compaction.resume_retry_error.countNumber of auto_sql_stats_compaction jobs which failed with a retriable errorcockroachdb
jobs_auto_update_sql_activity_currently_idlecockroachdb.jobs.auto_update_sql_activity.currently_idleNumber of auto_update_sql_activity jobs currently considered Idle and can be freely shut downcockroachdb
jobs_auto_update_sql_activity_currently_pausedcockroachdb.jobs.auto_update_sql_activity.currently_pausedNumber of auto_update_sql_activity jobs currently considered Pausedcockroachdb
jobs_auto_update_sql_activity_currently_runningcockroachdb.jobs.auto_update_sql_activity.currently_runningNumber of auto_update_sql_activity jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_auto_update_sql_activity_expired_pts_recordscockroachdb.jobs.auto_update_sql_activity.expired_pts_records.countNumber of expired protected timestamp records owned by auto_update_sql_activity jobscockroachdb
jobs_auto_update_sql_activity_fail_or_cancel_completedcockroachdb.jobs.auto_update_sql_activity.fail_or_cancel_completed.countNumber of auto_update_sql_activity jobs which successfully completed their failure or cancelation processcockroachdb
jobs_auto_update_sql_activity_fail_or_cancel_failedcockroachdb.jobs.auto_update_sql_activity.fail_or_cancel_failed.countNumber of auto_update_sql_activity jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_auto_update_sql_activity_fail_or_cancel_retry_errorcockroachdb.jobs.auto_update_sql_activity.fail_or_cancel_retry_error.countNumber of auto_update_sql_activity jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_auto_update_sql_activity_protected_age_seccockroachdb.jobs.auto_update_sql_activity.protected_age_secThe age of the oldest PTS record protected by auto_update_sql_activity jobscockroachdb
jobs_auto_update_sql_activity_protected_record_countcockroachdb.jobs.auto_update_sql_activity.protected_record_countNumber of protected timestamp records held by auto_update_sql_activity jobscockroachdb
jobs_auto_update_sql_activity_resume_completedcockroachdb.jobs.auto_update_sql_activity.resume_completed.countNumber of auto_update_sql_activity jobs which successfully resumed to completioncockroachdb
jobs_auto_update_sql_activity_resume_failedcockroachdb.jobs.auto_update_sql_activity.resume_failed.countNumber of auto_update_sql_activity jobs which failed with a non-retriable errorcockroachdb
jobs_auto_update_sql_activity_resume_retry_errorcockroachdb.jobs.auto_update_sql_activity.resume_retry_error.countNumber of auto_update_sql_activity jobs which failed with a retriable errorcockroachdb
jobs_backup_currently_idlecockroachdb.jobs.backup.currently_idleNumber of backup jobs currently considered Idle and can be freely shut downcockroachdb
jobs_backup_currently_pausedcockroachdb.jobs.backup.currently_pausedNumber of backup jobs currently considered Pausedcockroachdb
jobs_backup_currently_runningcockroachdb.jobs.backup.currently_runningNumber of backup jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_backup_expired_pts_recordscockroachdb.jobs.backup.expired_pts_records.countNumber of expired protected timestamp records owned by backup jobscockroachdb
jobs_backup_fail_or_cancel_completedcockroachdb.jobs.backup.fail_or_cancel_completed.countNumber of backup jobs which successfully completed their failure or cancelation processcockroachdb
jobs_backup_fail_or_cancel_failedcockroachdb.jobs.backup.fail_or_cancel_failed.countNumber of backup jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_backup_fail_or_cancel_retry_errorcockroachdb.jobs.backup.fail_or_cancel_retry_error.countNumber of backup jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_backup_protected_age_seccockroachdb.jobs.backup.protected_age_secThe age of the oldest PTS record protected by backup jobscockroachdb
jobs_backup_protected_record_countcockroachdb.jobs.backup.protected_record_countNumber of protected timestamp records held by backup jobscockroachdb
jobs_backup_resume_completedcockroachdb.jobs.backup.resume_completed.countNumber of backup jobs which successfully resumed to completioncockroachdb
jobs_backup_resume_failedcockroachdb.jobs.backup.resume_failed.countNumber of backup jobs which failed with a non-retriable errorcockroachdb
jobs_backup_resume_retry_errorcockroachdb.jobs.backup.resume_retry_error.countNumber of backup jobs which failed with a retriable errorcockroachdb
jobs_changefeed_currently_idlecockroachdb.jobs.changefeed.currently_idleNumber of changefeed jobs currently considered Idle and can be freely shut downcockroachdb
jobs_changefeed_currently_pausedcockroachdb.jobs.changefeed.currently_pausedNumber of changefeed jobs currently considered Pausedcockroachdb
jobs_changefeed_currently_runningcockroachdb.jobs.changefeed.currently_runningNumber of changefeed jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_changefeed_expired_pts_recordscockroachdb.jobs.changefeed.expired_pts_records.countNumber of expired protected timestamp records owned by changefeed jobscockroachdb
jobs_changefeed_fail_or_cancel_completedcockroachdb.jobs.changefeed.fail_or_cancel_completed.countNumber of changefeed jobs which successfully completed their failure or cancelation processcockroachdb
jobs_changefeed_fail_or_cancel_failedcockroachdb.jobs.changefeed.fail_or_cancel_failed.countNumber of changefeed jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_changefeed_fail_or_cancel_retry_errorcockroachdb.jobs.changefeed.fail_or_cancel_retry_error.countNumber of changefeed jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_changefeed_protected_age_seccockroachdb.jobs.changefeed.protected_age_secThe age of the oldest PTS record protected by changefeed jobscockroachdb
jobs_changefeed_protected_record_countcockroachdb.jobs.changefeed.protected_record_countNumber of protected timestamp records held by changefeed jobscockroachdb
jobs_changefeed_resume_completedcockroachdb.jobs.changefeed.resume_completed.countNumber of changefeed jobs which successfully resumed to completioncockroachdb
jobs_changefeed_resume_failedcockroachdb.jobs.changefeed.resume_failed.countNumber of changefeed jobs which failed with a non-retriable errorcockroachdb
jobs_changefeed_resume_retry_errorcockroachdb.jobs.changefeed.resume.retry.error.countNumber of changefeed jobs which failed with a retriable errorcockroachdb
jobs_changefeed_resume_retry_errorcockroachdb.jobs.changefeed.resume_retry_error.countNumber of changefeed jobs which failed with a retriable errorcockroachdb
jobs_claimed_jobscockroachdb.jobs.claimed_jobs.countnumber of jobs claimed in job-adopt iterationscockroachdb
jobs_create_stats_currently_idlecockroachdb.jobs.create_stats.currently_idleNumber of create_stats jobs currently considered Idle and can be freely shut downcockroachdb
jobs_create_stats_currently_pausedcockroachdb.jobs.create_stats.currently_pausedNumber of create_stats jobs currently considered Pausedcockroachdb
jobs_create_stats_currently_runningcockroachdb.jobs.create.stats.currently_runningNumber of create_stats jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_create_stats_currently_runningcockroachdb.jobs.create_stats.currently_runningNumber of create_stats jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_create_stats_expired_pts_recordscockroachdb.jobs.create_stats.expired_pts_records.countNumber of expired protected timestamp records owned by create_stats jobscockroachdb
jobs_create_stats_fail_or_cancel_completedcockroachdb.jobs.create_stats.fail_or_cancel_completed.countNumber of create_stats jobs which successfully completed their failure or cancelation processcockroachdb
jobs_create_stats_fail_or_cancel_failedcockroachdb.jobs.create_stats.fail_or_cancel_failed.countNumber of create_stats jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_create_stats_fail_or_cancel_retry_errorcockroachdb.jobs.create_stats.fail_or_cancel_retry_error.countNumber of create_stats jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_create_stats_protected_age_seccockroachdb.jobs.create_stats.protected_age_secThe age of the oldest PTS record protected by create_stats jobscockroachdb
jobs_create_stats_protected_record_countcockroachdb.jobs.create_stats.protected_record_countNumber of protected timestamp records held by create_stats jobscockroachdb
jobs_create_stats_resume_completedcockroachdb.jobs.create_stats.resume_completed.countNumber of create_stats jobs which successfully resumed to completioncockroachdb
jobs_create_stats_resume_failedcockroachdb.jobs.create_stats.resume_failed.countNumber of create_stats jobs which failed with a non-retriable errorcockroachdb
jobs_create_stats_resume_retry_errorcockroachdb.jobs.create_stats.resume_retry_error.countNumber of create_stats jobs which failed with a retriable errorcockroachdb
jobs_import_currently_idlecockroachdb.jobs.import.currently_idleNumber of import jobs currently considered Idle and can be freely shut downcockroachdb
jobs_import_currently_pausedcockroachdb.jobs.import.currently_pausedNumber of import jobs currently considered Pausedcockroachdb
jobs_import_currently_runningcockroachdb.jobs.import.currently_runningNumber of import jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_import_expired_pts_recordscockroachdb.jobs.import.expired_pts_records.countNumber of expired protected timestamp records owned by import jobscockroachdb
jobs_import_fail_or_cancel_completedcockroachdb.jobs.import.fail_or_cancel_completed.countNumber of import jobs which successfully completed their failure or cancelation processcockroachdb
jobs_import_fail_or_cancel_failedcockroachdb.jobs.import.fail_or_cancel_failed.countNumber of import jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_import_fail_or_cancel_retry_errorcockroachdb.jobs.import.fail_or_cancel_retry_error.countNumber of import jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_import_protected_age_seccockroachdb.jobs.import.protected_age_secThe age of the oldest PTS record protected by import jobscockroachdb
jobs_import_protected_record_countcockroachdb.jobs.import.protected_record_countNumber of protected timestamp records held by import jobscockroachdb
jobs_import_resume_completedcockroachdb.jobs.import.resume_completed.countNumber of import jobs which successfully resumed to completioncockroachdb
jobs_import_resume_failedcockroachdb.jobs.import.resume_failed.countNumber of import jobs which failed with a non-retriable errorcockroachdb
jobs_import_resume_retry_errorcockroachdb.jobs.import.resume_retry_error.countNumber of import jobs which failed with a retriable errorcockroachdb
jobs_key_visualizer_currently_idlecockroachdb.jobs.key_visualizer.currently_idleNumber of key_visualizer jobs currently considered Idle and can be freely shut downcockroachdb
jobs_key_visualizer_currently_pausedcockroachdb.jobs.key_visualizer.currently_pausedNumber of key_visualizer jobs currently considered Pausedcockroachdb
jobs_key_visualizer_currently_runningcockroachdb.jobs.key_visualizer.currently_runningNumber of key_visualizer jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_key_visualizer_expired_pts_recordscockroachdb.jobs.key_visualizer.expired_pts_records.countNumber of expired protected timestamp records owned by key_visualizer jobscockroachdb
jobs_key_visualizer_fail_or_cancel_completedcockroachdb.jobs.key_visualizer.fail_or_cancel_completed.countNumber of key_visualizer jobs which successfully completed their failure or cancelation processcockroachdb
jobs_key_visualizer_fail_or_cancel_failedcockroachdb.jobs.key_visualizer.fail_or_cancel_failed.countNumber of key_visualizer jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_key_visualizer_fail_or_cancel_retry_errorcockroachdb.jobs.key_visualizer.fail_or_cancel_retry_error.countNumber of key_visualizer jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_key_visualizer_protected_age_seccockroachdb.jobs.key_visualizer.protected_age_secThe age of the oldest PTS record protected by key_visualizer jobscockroachdb
jobs_key_visualizer_protected_record_countcockroachdb.jobs.key_visualizer.protected_record_countNumber of protected timestamp records held by key_visualizer jobscockroachdb
jobs_key_visualizer_resume_completedcockroachdb.jobs.key_visualizer.resume_completed.countNumber of key_visualizer jobs which successfully resumed to completioncockroachdb
jobs_key_visualizer_resume_failedcockroachdb.jobs.key_visualizer.resume_failed.countNumber of key_visualizer jobs which failed with a non-retriable errorcockroachdb
jobs_key_visualizer_resume_retry_errorcockroachdb.jobs.key_visualizer.resume_retry_error.countNumber of key_visualizer jobs which failed with a retriable errorcockroachdb
jobs_metrics_task_failedcockroachdb.jobs.metrics.task_failed.countNumber of metrics poller tasks that failedcockroachdb
jobs_migration_currently_idlecockroachdb.jobs.migration.currently_idleNumber of migration jobs currently considered Idle and can be freely shut downcockroachdb
jobs_migration_currently_pausedcockroachdb.jobs.migration.currently_pausedNumber of migration jobs currently considered Pausedcockroachdb
jobs_migration_currently_runningcockroachdb.jobs.migration.currently_runningNumber of migration jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_migration_expired_pts_recordscockroachdb.jobs.migration.expired_pts_records.countNumber of expired protected timestamp records owned by migration jobscockroachdb
jobs_migration_fail_or_cancel_completedcockroachdb.jobs.migration.fail_or_cancel_completed.countNumber of migration jobs which successfully completed their failure or cancelation processcockroachdb
jobs_migration_fail_or_cancel_failedcockroachdb.jobs.migration.fail_or_cancel_failed.countNumber of migration jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_migration_fail_or_cancel_retry_errorcockroachdb.jobs.migration.fail_or_cancel_retry_error.countNumber of migration jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_migration_protected_age_seccockroachdb.jobs.migration.protected_age_secThe age of the oldest PTS record protected by migration jobscockroachdb
jobs_migration_protected_record_countcockroachdb.jobs.migration.protected_record_countNumber of protected timestamp records held by migration jobscockroachdb
jobs_migration_resume_completedcockroachdb.jobs.migration.resume_completed.countNumber of migration jobs which successfully resumed to completioncockroachdb
jobs_migration_resume_failedcockroachdb.jobs.migration.resume_failed.countNumber of migration jobs which failed with a non-retriable errorcockroachdb
jobs_migration_resume_retry_errorcockroachdb.jobs.migration.resume_retry_error.countNumber of migration jobs which failed with a retriable errorcockroachdb
jobs_mvcc_statistics_update_currently_idlecockroachdb.jobs.mvcc_statistics_update.currently_idleNumber of mvcc_statistics_update jobs currently considered Idle and can be freely shut downcockroachdb
jobs_mvcc_statistics_update_currently_pausedcockroachdb.jobs.mvcc_statistics_update.currently_pausedNumber of mvcc_statistics_update jobs currently considered Pausedcockroachdb
jobs_mvcc_statistics_update_currently_runningcockroachdb.jobs.mvcc_statistics_update.currently_runningNumber of mvcc_statistics_update jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_mvcc_statistics_update_expired_pts_recordscockroachdb.jobs.mvcc_statistics_update.expired_pts_records.countNumber of expired protected timestamp records owned by mvcc_statistics_update jobscockroachdb
jobs_mvcc_statistics_update_fail_or_cancel_completedcockroachdb.jobs.mvcc_statistics_update.fail_or_cancel_completed.countNumber of mvcc_statistics_update jobs which successfully completed their failure or cancelation processcockroachdb
jobs_mvcc_statistics_update_fail_or_cancel_failedcockroachdb.jobs.mvcc_statistics_update.fail_or_cancel_failed.countNumber of mvcc_statistics_update jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_mvcc_statistics_update_fail_or_cancel_retry_errorcockroachdb.jobs.mvcc_statistics_update.fail_or_cancel_retry_error.countNumber of mvcc_statistics_update jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_mvcc_statistics_update_protected_age_seccockroachdb.jobs.mvcc_statistics_update.protected_age_secThe age of the oldest PTS record protected by mvcc_statistics_update jobscockroachdb
jobs_mvcc_statistics_update_protected_record_countcockroachdb.jobs.mvcc_statistics_update.protected_record_countNumber of protected timestamp records held by mvcc_statistics_update jobscockroachdb
jobs_mvcc_statistics_update_resume_completedcockroachdb.jobs.mvcc_statistics_update.resume_completed.countNumber of mvcc_statistics_update jobs which successfully resumed to completioncockroachdb
jobs_mvcc_statistics_update_resume_failedcockroachdb.jobs.mvcc_statistics_update.resume_failed.countNumber of mvcc_statistics_update jobs which failed with a non-retriable errorcockroachdb
jobs_mvcc_statistics_update_resume_retry_errorcockroachdb.jobs.mvcc_statistics_update.resume_retry_error.countNumber of mvcc_statistics_update jobs which failed with a retriable errorcockroachdb
jobs_new_schema_change_currently_idlecockroachdb.jobs.new_schema_change.currently_idleNumber of new_schema_change jobs currently considered Idle and can be freely shut downcockroachdb
jobs_new_schema_change_currently_pausedcockroachdb.jobs.new_schema_change.currently_pausedNumber of new_schema_change jobs currently considered Pausedcockroachdb
jobs_new_schema_change_currently_runningcockroachdb.jobs.new_schema_change.currently_runningNumber of new_schema_change jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_new_schema_change_expired_pts_recordscockroachdb.jobs.new_schema_change.expired_pts_records.countNumber of expired protected timestamp records owned by new_schema_change jobscockroachdb
jobs_new_schema_change_fail_or_cancel_completedcockroachdb.jobs.new_schema_change.fail_or_cancel_completed.countNumber of new_schema_change jobs which successfully completed their failure or cancelation processcockroachdb
jobs_new_schema_change_fail_or_cancel_failedcockroachdb.jobs.new_schema_change.fail_or_cancel_failed.countNumber of new_schema_change jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_new_schema_change_fail_or_cancel_retry_errorcockroachdb.jobs.new_schema_change.fail_or_cancel_retry_error.countNumber of new_schema_change jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_new_schema_change_protected_age_seccockroachdb.jobs.new_schema_change.protected_age_secThe age of the oldest PTS record protected by new_schema_change jobscockroachdb
jobs_new_schema_change_protected_record_countcockroachdb.jobs.new_schema_change.protected_record_countNumber of protected timestamp records held by new_schema_change jobscockroachdb
jobs_new_schema_change_resume_completedcockroachdb.jobs.new_schema_change.resume_completed.countNumber of new_schema_change jobs which successfully resumed to completioncockroachdb
jobs_new_schema_change_resume_failedcockroachdb.jobs.new_schema_change.resume_failed.countNumber of new_schema_change jobs which failed with a non-retriable errorcockroachdb
jobs_new_schema_change_resume_retry_errorcockroachdb.jobs.new_schema_change.resume_retry_error.countNumber of new_schema_change jobs which failed with a retriable errorcockroachdb
jobs_poll_jobs_stats_currently_idlecockroachdb.jobs.poll_jobs_stats.currently_idleNumber of poll_jobs_stats jobs currently considered Idle and can be freely shut downcockroachdb
jobs_poll_jobs_stats_currently_pausedcockroachdb.jobs.poll_jobs_stats.currently_pausedNumber of poll_jobs_stats jobs currently considered Pausedcockroachdb
jobs_poll_jobs_stats_currently_runningcockroachdb.jobs.poll_jobs_stats.currently_runningNumber of poll_jobs_stats jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_poll_jobs_stats_expired_pts_recordscockroachdb.jobs.poll_jobs_stats.expired_pts_records.countNumber of expired protected timestamp records owned by poll_jobs_stats jobscockroachdb
jobs_poll_jobs_stats_fail_or_cancel_completedcockroachdb.jobs.poll_jobs_stats.fail_or_cancel_completed.countNumber of poll_jobs_stats jobs which successfully completed their failure or cancelation processcockroachdb
jobs_poll_jobs_stats_fail_or_cancel_failedcockroachdb.jobs.poll_jobs_stats.fail_or_cancel_failed.countNumber of poll_jobs_stats jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_poll_jobs_stats_fail_or_cancel_retry_errorcockroachdb.jobs.poll_jobs_stats.fail_or_cancel_retry_error.countNumber of poll_jobs_stats jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_poll_jobs_stats_protected_age_seccockroachdb.jobs.poll_jobs_stats.protected_age_secThe age of the oldest PTS record protected by poll_jobs_stats jobscockroachdb
jobs_poll_jobs_stats_protected_record_countcockroachdb.jobs.poll_jobs_stats.protected_record_countNumber of protected timestamp records held by poll_jobs_stats jobscockroachdb
jobs_poll_jobs_stats_resume_completedcockroachdb.jobs.poll_jobs_stats.resume_completed.countNumber of poll_jobs_stats jobs which successfully resumed to completioncockroachdb
jobs_poll_jobs_stats_resume_failedcockroachdb.jobs.poll_jobs_stats.resume_failed.countNumber of poll_jobs_stats jobs which failed with a non-retriable errorcockroachdb
jobs_poll_jobs_stats_resume_retry_errorcockroachdb.jobs.poll_jobs_stats.resume_retry_error.countNumber of poll_jobs_stats jobs which failed with a retriable errorcockroachdb
jobs_replication_stream_ingestion_currently_idlecockroachdb.jobs.replication_stream_ingestion.currently_idleNumber of replication_stream_ingestion jobs currently considered Idle and can be freely shut downcockroachdb
jobs_replication_stream_ingestion_currently_pausedcockroachdb.jobs.replication_stream_ingestion.currently_pausedNumber of replication_stream_ingestion jobs currently considered Pausedcockroachdb
jobs_replication_stream_ingestion_currently_runningcockroachdb.jobs.replication_stream_ingestion.currently_runningNumber of replication_stream_ingestion jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_replication_stream_ingestion_expired_pts_recordscockroachdb.jobs.replication_stream_ingestion.expired_pts_records.countNumber of expired protected timestamp records owned by replication_stream_ingestion jobscockroachdb
jobs_replication_stream_ingestion_fail_or_cancel_completedcockroachdb.jobs.replication_stream_ingestion.fail_or_cancel_completed.countNumber of replication_stream_ingestion jobs which successfully completed their failure or cancelation processcockroachdb
jobs_replication_stream_ingestion_fail_or_cancel_failedcockroachdb.jobs.replication_stream_ingestion.fail_or_cancel_failed.countNumber of replication_stream_ingestion jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_replication_stream_ingestion_fail_or_cancel_retry_errorcockroachdb.jobs.replication_stream_ingestion.fail_or_cancel_retry_error.countNumber of replication_stream_ingestion jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_replication_stream_ingestion_protected_age_seccockroachdb.jobs.replication_stream_ingestion.protected_age_secThe age of the oldest PTS record protected by replication_stream_ingestion jobscockroachdb
jobs_replication_stream_ingestion_protected_record_countcockroachdb.jobs.replication_stream_ingestion.protected_record_countNumber of protected timestamp records held by replication_stream_ingestion jobscockroachdb
jobs_replication_stream_ingestion_resume_completedcockroachdb.jobs.replication_stream_ingestion.resume_completed.countNumber of replication_stream_ingestion jobs which successfully resumed to completioncockroachdb
jobs_replication_stream_ingestion_resume_failedcockroachdb.jobs.replication_stream_ingestion.resume_failed.countNumber of replication_stream_ingestion jobs which failed with a non-retriable errorcockroachdb
jobs_replication_stream_ingestion_resume_retry_errorcockroachdb.jobs.replication_stream_ingestion.resume_retry_error.countNumber of replication_stream_ingestion jobs which failed with a retriable errorcockroachdb
jobs_replication_stream_producer_currently_idlecockroachdb.jobs.replication_stream_producer.currently_idleNumber of replication_stream_producer jobs currently considered Idle and can be freely shut downcockroachdb
jobs_replication_stream_producer_currently_pausedcockroachdb.jobs.replication_stream_producer.currently_pausedNumber of replication_stream_producer jobs currently considered Pausedcockroachdb
jobs_replication_stream_producer_currently_runningcockroachdb.jobs.replication_stream_producer.currently_runningNumber of replication_stream_producer jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_replication_stream_producer_expired_pts_recordscockroachdb.jobs.replication_stream_producer.expired_pts_records.countNumber of expired protected timestamp records owned by replication_stream_producer jobscockroachdb
jobs_replication_stream_producer_fail_or_cancel_completedcockroachdb.jobs.replication_stream_producer.fail_or_cancel_completed.countNumber of replication_stream_producer jobs which successfully completed their failure or cancelation processcockroachdb
jobs_replication_stream_producer_fail_or_cancel_failedcockroachdb.jobs.replication_stream_producer.fail_or_cancel_failed.countNumber of replication_stream_producer jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_replication_stream_producer_fail_or_cancel_retry_errorcockroachdb.jobs.replication_stream_producer.fail_or_cancel_retry_error.countNumber of replication_stream_producer jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_replication_stream_producer_protected_age_seccockroachdb.jobs.replication_stream_producer.protected_age_secThe age of the oldest PTS record protected by replication_stream_producer jobscockroachdb
jobs_replication_stream_producer_protected_record_countcockroachdb.jobs.replication_stream_producer.protected_record_countNumber of protected timestamp records held by replication_stream_producer jobscockroachdb
jobs_replication_stream_producer_resume_completedcockroachdb.jobs.replication_stream_producer.resume_completed.countNumber of replication_stream_producer jobs which successfully resumed to completioncockroachdb
jobs_replication_stream_producer_resume_failedcockroachdb.jobs.replication_stream_producer.resume_failed.countNumber of replication_stream_producer jobs which failed with a non-retriable errorcockroachdb
jobs_replication_stream_producer_resume_retry_errorcockroachdb.jobs.replication_stream_producer.resume_retry_error.countNumber of replication_stream_producer jobs which failed with a retriable errorcockroachdb
jobs_restore_currently_idlecockroachdb.jobs.restore.currently_idleNumber of restore jobs currently considered Idle and can be freely shut downcockroachdb
jobs_restore_currently_pausedcockroachdb.jobs.restore.currently_pausedNumber of restore jobs currently considered Pausedcockroachdb
jobs_restore_currently_runningcockroachdb.jobs.restore.currently_runningNumber of restore jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_restore_expired_pts_recordscockroachdb.jobs.restore.expired_pts_records.countNumber of expired protected timestamp records owned by restore jobscockroachdb
jobs_restore_fail_or_cancel_completedcockroachdb.jobs.restore.fail_or_cancel_completed.countNumber of restore jobs which successfully completed their failure or cancelation processcockroachdb
jobs_restore_fail_or_cancel_failedcockroachdb.jobs.restore.fail_or_cancel_failed.countNumber of restore jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_restore_fail_or_cancel_retry_errorcockroachdb.jobs.restore.fail_or_cancel_retry_error.countNumber of restore jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_restore_protected_age_seccockroachdb.jobs.restore.protected_age_secThe age of the oldest PTS record protected by restore jobscockroachdb
jobs_restore_protected_record_countcockroachdb.jobs.restore.protected_record_countNumber of protected timestamp records held by restore jobscockroachdb
jobs_restore_resume_completedcockroachdb.jobs.restore.resume_completed.countNumber of restore jobs which successfully resumed to completioncockroachdb
jobs_restore_resume_failedcockroachdb.jobs.restore.resume_failed.countNumber of restore jobs which failed with a non-retriable errorcockroachdb
jobs_restore_resume_retry_errorcockroachdb.jobs.restore.resume_retry_error.countNumber of restore jobs which failed with a retriable errorcockroachdb
jobs_resumed_claimed_jobscockroachdb.jobs.resumed_claimed_jobs.countnumber of claimed-jobs resumed in job-adopt iterationscockroachdb
jobs_row_level_ttl_currently_idlecockroachdb.jobs.row_level_ttl.currently_idleNumber of row_level_ttl jobs currently considered Idle and can be freely shut downcockroachdb
jobs_row_level_ttl_currently_pausedcockroachdb.jobs.row.level.ttl.currently_pausedNumber of row_level_ttl jobs currently considered Pausedcockroachdb
jobs_row_level_ttl_currently_pausedcockroachdb.jobs.row_level_ttl.currently_pausedNumber of row_level_ttl jobs currently considered Pausedcockroachdb
jobs_row_level_ttl_currently_runningcockroachdb.jobs.row.level.ttl.currently_runningNumber of row_level_ttl jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_row_level_ttl_currently_runningcockroachdb.jobs.row_level_ttl.currently_runningNumber of row_level_ttl jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_row_level_ttl_delete_durationcockroachdb.jobs.row_level_ttl.delete_duration.countDuration for delete requests during row level TTL.cockroachdb
jobs_row_level_ttl_expired_pts_recordscockroachdb.jobs.row_level_ttl.expired_pts_records.countNumber of expired protected timestamp records owned by row_level_ttl jobscockroachdb
jobs_row_level_ttl_fail_or_cancel_completedcockroachdb.jobs.row_level_ttl.fail_or_cancel_completed.countNumber of row_level_ttl jobs which successfully completed their failure or cancelation processcockroachdb
jobs_row_level_ttl_fail_or_cancel_failedcockroachdb.jobs.row_level_ttl.fail_or_cancel_failed.countNumber of row_level_ttl jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_row_level_ttl_fail_or_cancel_retry_errorcockroachdb.jobs.row_level_ttl.fail_or_cancel_retry_error.countNumber of row_level_ttl jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_row_level_ttl_num_active_spanscockroachdb.jobs.row_level_ttl.num_active_spansNumber of active spans the TTL job is deleting from.cockroachdb
jobs_row_level_ttl_protected_age_seccockroachdb.jobs.row_level_ttl.protected_age_secThe age of the oldest PTS record protected by row_level_ttl jobscockroachdb
jobs_row_level_ttl_protected_record_countcockroachdb.jobs.row_level_ttl.protected_record_countNumber of protected timestamp records held by row_level_ttl jobscockroachdb
jobs_row_level_ttl_resume_completedcockroachdb.jobs.row.level.ttl.resume_completed.countNumber of row_level_ttl jobs which successfully resumed to completioncockroachdb
jobs_row_level_ttl_resume_completedcockroachdb.jobs.row_level_ttl.resume_completed.countNumber of row_level_ttl jobs which successfully resumed to completioncockroachdb
jobs_row_level_ttl_resume_failedcockroachdb.jobs.row_level_ttl.resume_failed.countNumber of row_level_ttl jobs which failed with a non-retriable errorcockroachdb
jobs_row_level_ttl_resume_failedcockroachdb.jobs.row.level.ttl.resume_failed.countNumber of row_level_ttl jobs which failed with a non-retriable errorcockroachdb
jobs_row_level_ttl_resume_retry_errorcockroachdb.jobs.row_level_ttl.resume_retry_error.countNumber of row_level_ttl jobs which failed with a retriable errorcockroachdb
jobs_row_level_ttl_rows_deletedcockroachdb.jobs.row_level_ttl.rows_deleted.countNumber of rows deleted by the row level TTL job.cockroachdb
jobs_row_level_ttl_rows_deletedcockroachdb.jobs.row.level.ttl.rows_deleted.countNumber of rows deleted by the row level TTL job.cockroachdb
jobs_row_level_ttl_rows_selectedcockroachdb.jobs.row_level_ttl.rows_selected.countNumber of rows selected for deletion by the row level TTL job.cockroachdb
jobs_row_level_ttl_rows_selectedcockroachdb.jobs.row.level.ttl.rows_selected.countNumber of rows selected for deletion by the row level TTL job.cockroachdb
jobs_row_level_ttl_select_durationcockroachdb.jobs.row_level_ttl.select_duration.countDuration for select requests during row level TTL.cockroachdb
jobs_row_level_ttl_span_total_durationcockroachdb.jobs.row_level_ttl.span_total_duration.countDuration for processing a span during row level TTL.cockroachdb
jobs_row_level_ttl_total_expired_rowscockroachdb.jobs.row_level_ttl.total_expired_rowsApproximate number of rows that have expired the TTL on the TTL table.cockroachdb
jobs_row_level_ttl_total_rowscockroachdb.jobs.row_level_ttl.total_rowsApproximate number of rows on the TTL table.cockroachdb
jobs_running_non_idlecockroachdb.jobs.running_non_idlenumber of running jobs that are not idlecockroachdb
jobs_schema_change_currently_idlecockroachdb.jobs.schema_change.currently_idleNumber of schema_change jobs currently considered Idle and can be freely shut downcockroachdb
jobs_schema_change_currently_pausedcockroachdb.jobs.schema_change.currently_pausedNumber of schema_change jobs currently considered Pausedcockroachdb
jobs_schema_change_currently_runningcockroachdb.jobs.schema_change.currently_runningNumber of schema_change jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_schema_change_expired_pts_recordscockroachdb.jobs.schema_change.expired_pts_records.countNumber of expired protected timestamp records owned by schema_change jobscockroachdb
jobs_schema_change_fail_or_cancel_completedcockroachdb.jobs.schema_change.fail_or_cancel_completed.countNumber of schema_change jobs which successfully completed their failure or cancelation processcockroachdb
jobs_schema_change_fail_or_cancel_failedcockroachdb.jobs.schema_change.fail_or_cancel_failed.countNumber of schema_change jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_schema_change_fail_or_cancel_retry_errorcockroachdb.jobs.schema_change.fail_or_cancel_retry_error.countNumber of schema_change jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_schema_change_gc_currently_idlecockroachdb.jobs.schema_change_gc.currently_idleNumber of schema_change_gc jobs currently considered Idle and can be freely shut downcockroachdb
jobs_schema_change_gc_currently_pausedcockroachdb.jobs.schema_change_gc.currently_pausedNumber of schema_change_gc jobs currently considered Pausedcockroachdb
jobs_schema_change_gc_currently_runningcockroachdb.jobs.schema_change_gc.currently_runningNumber of schema_change_gc jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_schema_change_gc_expired_pts_recordscockroachdb.jobs.schema_change_gc.expired_pts_records.countNumber of expired protected timestamp records owned by schema_change_gc jobscockroachdb
jobs_schema_change_gc_fail_or_cancel_completedcockroachdb.jobs.schema_change_gc.fail_or_cancel_completed.countNumber of schema_change_gc jobs which successfully completed their failure or cancelation processcockroachdb
jobs_schema_change_gc_fail_or_cancel_failedcockroachdb.jobs.schema_change_gc.fail_or_cancel_failed.countNumber of schema_change_gc jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_schema_change_gc_fail_or_cancel_retry_errorcockroachdb.jobs.schema_change_gc.fail_or_cancel_retry_error.countNumber of schema_change_gc jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_schema_change_gc_protected_age_seccockroachdb.jobs.schema_change_gc.protected_age_secThe age of the oldest PTS record protected by schema_change_gc jobscockroachdb
jobs_schema_change_gc_protected_record_countcockroachdb.jobs.schema_change_gc.protected_record_countNumber of protected timestamp records held by schema_change_gc jobscockroachdb
jobs_schema_change_gc_resume_completedcockroachdb.jobs.schema_change_gc.resume_completed.countNumber of schema_change_gc jobs which successfully resumed to completioncockroachdb
jobs_schema_change_gc_resume_failedcockroachdb.jobs.schema_change_gc.resume_failed.countNumber of schema_change_gc jobs which failed with a non-retriable errorcockroachdb
jobs_schema_change_gc_resume_retry_errorcockroachdb.jobs.schema_change_gc.resume_retry_error.countNumber of schema_change_gc jobs which failed with a retriable errorcockroachdb
jobs_schema_change_protected_age_seccockroachdb.jobs.schema_change.protected_age_secThe age of the oldest PTS record protected by schema_change jobscockroachdb
jobs_schema_change_protected_record_countcockroachdb.jobs.schema_change.protected_record_countNumber of protected timestamp records held by schema_change jobscockroachdb
jobs_schema_change_resume_completedcockroachdb.jobs.schema_change.resume_completed.countNumber of schema_change jobs which successfully resumed to completioncockroachdb
jobs_schema_change_resume_failedcockroachdb.jobs.schema_change.resume_failed.countNumber of schema_change jobs which failed with a non-retriable errorcockroachdb
jobs_schema_change_resume_retry_errorcockroachdb.jobs.schema_change.resume_retry_error.countNumber of schema_change jobs which failed with a retriable errorcockroachdb
jobs_typedesc_schema_change_currently_idlecockroachdb.jobs.typedesc_schema_change.currently_idleNumber of typedesc_schema_change jobs currently considered Idle and can be freely shut downcockroachdb
jobs_typedesc_schema_change_currently_pausedcockroachdb.jobs.typedesc_schema_change.currently_pausedNumber of typedesc_schema_change jobs currently considered Pausedcockroachdb
jobs_typedesc_schema_change_currently_runningcockroachdb.jobs.typedesc_schema_change.currently_runningNumber of typedesc_schema_change jobs currently running in Resume or OnFailOrCancel statecockroachdb
jobs_typedesc_schema_change_expired_pts_recordscockroachdb.jobs.typedesc_schema_change.expired_pts_records.countNumber of expired protected timestamp records owned by typedesc_schema_change jobscockroachdb
jobs_typedesc_schema_change_fail_or_cancel_completedcockroachdb.jobs.typedesc_schema_change.fail_or_cancel_completed.countNumber of typedesc_schema_change jobs which successfully completed their failure or cancelation processcockroachdb
jobs_typedesc_schema_change_fail_or_cancel_failedcockroachdb.jobs.typedesc_schema_change.fail_or_cancel_failed.countNumber of typedesc_schema_change jobs which failed with a non-retriable error on their failure or cancelation processcockroachdb
jobs_typedesc_schema_change_fail_or_cancel_retry_errorcockroachdb.jobs.typedesc_schema_change.fail_or_cancel_retry_error.countNumber of typedesc_schema_change jobs which failed with a retriable error on their failure or cancelation processcockroachdb
jobs_typedesc_schema_change_protected_age_seccockroachdb.jobs.typedesc_schema_change.protected_age_secThe age of the oldest PTS record protected by typedesc_schema_change jobscockroachdb
jobs_typedesc_schema_change_protected_record_countcockroachdb.jobs.typedesc_schema_change.protected_record_countNumber of protected timestamp records held by typedesc_schema_change jobscockroachdb
jobs_typedesc_schema_change_resume_completedcockroachdb.jobs.typedesc_schema_change.resume_completed.countNumber of typedesc_schema_change jobs which successfully resumed to completioncockroachdb
jobs_typedesc_schema_change_resume_failedcockroachdb.jobs.typedesc_schema_change.resume_failed.countNumber of typedesc_schema_change jobs which failed with a non-retriable errorcockroachdb
jobs_typedesc_schema_change_resume_retry_errorcockroachdb.jobs.typedesc_schema_change.resume_retry_error.countNumber of typedesc_schema_change jobs which failed with a retriable errorcockroachdb
keybytescockroachdb.keybytesNumber of bytes taken up by keyscockroachdb
keycountcockroachdb.keycountCount of all keyscockroachdb
kv_allocator_load_based_lease_transfers_cannot_find_better_candidatecockroachdb.kv.allocator.load_based_lease_transfers.cannot_find_better_candidate.countThe number times the allocator determined that the lease was on the best possible replicacockroachdb
kv_allocator_load_based_lease_transfers_delta_not_significantcockroachdb.kv.allocator.load_based_lease_transfers.delta_not_significant.countThe number times the allocator determined that the delta between the existing store and the best candidate was not significantcockroachdb
kv_allocator_load_based_lease_transfers_existing_not_overfullcockroachdb.kv.allocator.load_based_lease_transfers.existing_not_overfull.countThe number times the allocator determined that the lease was not on an overfull storecockroachdb
kv_allocator_load_based_lease_transfers_follow_the_workloadcockroachdb.kv.allocator.load_based_lease_transfers.follow_the_workload.countThe number times the allocator determined that the lease should be transferred to another replica for locality.cockroachdb
kv_allocator_load_based_lease_transfers_missing_stats_for_existing_storescockroachdb.kv.allocator.load_based_lease_transfers.missing_stats_for_existing_stores.countThe number times the allocator was missing qps stats for the leaseholdercockroachdb
kv_allocator_load_based_lease_transfers_should_transfercockroachdb.kv.allocator.load_based_lease_transfers.should_transfer.countThe number times the allocator determined that the lease should be transferred to another replica for better load distributioncockroachdb
kv_allocator_load_based_replica_rebalancing_cannot_find_better_candidatecockroachdb.kv.allocator.load_based_replica_rebalancing.cannot_find_better_candidate.countThe number times the allocator determined that the range was on the best possible storescockroachdb
kv_allocator_load_based_replica_rebalancing_delta_not_significantcockroachdb.kv.allocator.load_based_replica_rebalancing.delta_not_significant.countThe number times the allocator determined that the delta between an existing store and the best replacement candidate was not high enoughcockroachdb
kv_allocator_load_based_replica_rebalancing_existing_not_overfullcockroachdb.kv.allocator.load_based_replica_rebalancing.existing_not_overfull.countThe number times the allocator determined that none of the range’s replicas were on overfull storescockroachdb
kv_allocator_load_based_replica_rebalancing_missing_stats_for_existing_storecockroachdb.kv.allocator.load_based_replica_rebalancing.missing_stats_for_existing_store.countThe number times the allocator was missing the qps stats for the existing storecockroachdb
kv_allocator_load_based_replica_rebalancing_should_transfercockroachdb.kv.allocator.load_based_replica_rebalancing.should_transfer.countThe number times the allocator determined that the replica should be rebalanced to another store for better load distributioncockroachdb
kv_closed_timestamp_max_behind_nanoscockroachdb.kv.closed_timestamp.max_behind_nanosLargest latency between realtime and replica max closed timestampcockroachdb
kv_concurrency_avg_lock_hold_duration_nanoscockroachdb.kv.concurrency.avg_lock_hold_duration_nanosAverage lock hold duration across locks currently held in lock tables. Does not include replicated locks (intents) that are not held in memorycockroachdb
kv_concurrency_avg_lock_wait_duration_nanoscockroachdb.kv.concurrency.avg_lock_wait_duration_nanosAverage lock wait duration across requests currently waiting in lock wait-queuescockroachdb
kv_concurrency_lock_wait_queue_waiterscockroachdb.kv.concurrency.lock_wait_queue_waitersNumber of requests actively waiting in a lock wait-queuecockroachdb
kv_concurrency_lockscockroachdb.kv.concurrency.locksNumber of active locks held in lock tables. Does not include replicated locks (intents) that are not held in memorycockroachdb
kv_concurrency_locks_with_wait_queuescockroachdb.kv.concurrency.locks_with_wait_queuesNumber of active locks held in lock tables with active wait-queuescockroachdb
kv_concurrency_max_lock_hold_duration_nanoscockroachdb.kv.concurrency.max_lock_hold_duration_nanosMaximum length of time any lock in a lock table is held. Does not include replicated locks (intents) that are not held in memorycockroachdb
kv_concurrency_max_lock_wait_duration_nanoscockroachdb.kv.concurrency.max_lock_wait_duration_nanosMaximum lock wait duration across requests currently waiting in lock wait-queuescockroachdb
kv_concurrency_max_lock_wait_queue_waiters_for_lockcockroachdb.kv.concurrency.max_lock_wait_queue_waiters_for_lockMaximum number of requests actively waiting in any single lock wait-queuecockroachdb
kv_loadsplitter_nosplitkeycockroachdb.kv.loadsplitter.nosplitkey.countLoad-based splitter could not find a split key.cockroachdb
kv_loadsplitter_popularkeycockroachdb.kv.loadsplitter.popularkey.countLoad-based splitter could not find a split key and the most popular sampled split key occurs in >= 25% of the samples.cockroachdb
kv_prober_planning_attemptscockroachdb.kv.prober.planning_attempts.countNumber of attempts at planning out probes made; in order to probe KV we need to plan out which ranges to probe;cockroachdb
kv_prober_planning_failurescockroachdb.kv.prober.planning_failures.countNumber of attempts at planning out probes that failed; in order to probe KV we need to plan out which ranges to probe; if planning fails, then kvprober is not able to send probes to all ranges; consider alerting on this metric as a resultcockroachdb
kv_prober_read_attemptscockroachdb.kv.prober.read.attempts.countNumber of attempts made to read probe KV, regardless of outcomecockroachdb
kv_prober_read_failurescockroachdb.kv.prober.read.failures.countNumber of attempts made to read probe KV that failed, whether due to error or timeoutcockroachdb
kv_prober_read_latencycockroachdb.kv.prober.read.latency.countLatency of successful KV read probescockroachdb
kv_prober_write_attemptscockroachdb.kv.prober.write.attempts.countNumber of attempts made to write probe KV, regardless of outcomecockroachdb
kv_prober_write_failurescockroachdb.kv.prober.write.failures.countNumber of attempts made to write probe KV that failed, whether due to error or timeoutcockroachdb
kv_prober_write_latencycockroachdb.kv.prober.write.latency.countLatency of successful KV write probescockroachdb
kv_prober_write_quarantine_oldest_durationcockroachdb.kv.prober.write.quarantine.oldest_durationThe duration that the oldest range in the write quarantine pool has remainedcockroachdb
kv_protectedts_reconciliation_errorscockroachdb.kv.protectedts.reconciliation.errors.countnumber of errors encountered during reconciliation runs on this nodecockroachdb
kv_protectedts_reconciliation_num_runscockroachdb.kv.protectedts.reconciliation.num_runs.countnumber of successful reconciliation runs on this nodecockroachdb
kv_protectedts_reconciliation_records_processedcockroachdb.kv.protectedts.reconciliation.records_processed.countnumber of records processed without error during reconciliation on this nodecockroachdb
kv_protectedts_reconciliation_records_removedcockroachdb.kv.protectedts.reconciliation.records_removed.countnumber of records removed during reconciliation runs on this nodecockroachdb
kv_rangefeed_budget_allocation_blockedcockroachdb.kv.rangefeed.budget_allocation_blocked.countNumber of times RangeFeed waited for budget availabilitycockroachdb
kv_rangefeed_budget_allocation_failedcockroachdb.kv.rangefeed.budget_allocation_failed.countNumber of times RangeFeed failed because memory budget was exceededcockroachdb
kv_rangefeed_catchup_scan_nanoscockroachdb.kv.rangefeed.catchup_scan_nanos.countTime spent in RangeFeed catchup scancockroachdb
kv_rangefeed_mem_sharedcockroachdb.kv.rangefeed.mem_sharedMemory usage by rangefeedscockroachdb
kv_rangefeed_mem_systemcockroachdb.kv.rangefeed.mem_systemMemory usage by rangefeeds on system rangescockroachdb
kv_rangefeed_processors_goroutinecockroachdb.kv.rangefeed.processors_goroutineNumber of active RangeFeed processors using goroutinescockroachdb
kv_rangefeed_processors_schedulercockroachdb.kv.rangefeed.processors_schedulerNumber of active RangeFeed processors using schedulercockroachdb
kv_rangefeed_registrationscockroachdb.kv.rangefeed.registrationsNumber of active RangeFeed registrationscockroachdb
kv_rangefeed_scheduler_normal_latencycockroachdb.kv.rangefeed.scheduler.normal.latency.countKV RangeFeed normal scheduler latencycockroachdb
kv_rangefeed_scheduler_normal_queue_sizecockroachdb.kv.rangefeed.scheduler.normal.queue_sizeNumber of entries in the KV RangeFeed normal scheduler queuecockroachdb
kv_rangefeed_scheduler_system_latencycockroachdb.kv.rangefeed.scheduler.system.latency.countKV RangeFeed system scheduler latencycockroachdb
kv_rangefeed_scheduler_system_queue_sizecockroachdb.kv.rangefeed.scheduler.system.queue_sizeNumber of entries in the KV RangeFeed system scheduler queuecockroachdb
kv_replica_circuit_breaker_num_tripped_eventscockroachdb.kv.replica_circuit_breaker.num_tripped_events.countNumber of times the per-Replica circuit breakers tripped since process start.cockroachdb
kv_replica_circuit_breaker_num_tripped_replicascockroachdb.kv.replica_circuit_breaker.num_tripped_replicasNumber of Replicas for which the per-Replica circuit breaker is currently tripped. A nonzero value indicates range or replica unavailability, and should be investigated. Replicas in this state will fail-fast all inbound requests.cockroachdb
kv_replica_read_batch_evaluate_dropped_latches_before_evalcockroachdb.kv.replica_read_batch_evaluate.dropped_latches_before_eval.countNumber of times read-only batches dropped latches before evaluation.cockroachdb
kv_replica_read_batch_evaluate_latencycockroachdb.kv.replica_read_batch_evaluate.latency.countExecution duration for evaluating a BatchRequest on the read-only path after latches have been acquired. A measurement is recorded regardless of outcome (i.e. also in case of an error). If internal retries occur, each instance is recorded separately.cockroachdb
kv_replica_read_batch_evaluate_without_interleaving_itercockroachdb.kv.replica_read_batch_evaluate.without_interleaving_iter.countNumber of read-only batches evaluated without an intent interleaving iter.cockroachdb
kv_replica_write_batch_evaluate_latencycockroachdb.kv.replica_write_batch_evaluate.latency.countExecution duration for evaluating a BatchRequest on the read-write path after latches have been acquired. A measurement is recorded regardless of outcome (i.e. also in case of an error). If internal retries occur, each instance is recorded separately. Note that the measurement does not include the duration for replicating the evaluated command.cockroachdb
kv_tenant_rate_limit_current_blockedcockroachdb.kv.tenant_rate_limit.current_blockedNumber of requests currently blocked by the rate limitercockroachdb
kv_tenant_rate_limit_num_tenantscockroachdb.kv.tenant_rate_limit.num_tenantsNumber of tenants currently being trackedcockroachdb
kv_tenant_rate_limit_read_batches_admittedcockroachdb.kv.tenant_rate_limit.read_batches_admitted.countNumber of read batches admitted by the rate limitercockroachdb
kv_tenant_rate_limit_read_bytes_admittedcockroachdb.kv.tenant_rate_limit.read_bytes_admitted.countNumber of read bytes admitted by the rate limitercockroachdb
kv_tenant_rate_limit_read_requests_admittedcockroachdb.kv.tenant_rate_limit.read_requests_admitted.countNumber of read requests admitted by the rate limitercockroachdb
kv_tenant_rate_limit_write_batches_admittedcockroachdb.kv.tenant_rate_limit.write_batches_admitted.countNumber of write batches admitted by the rate limitercockroachdb
kv_tenant_rate_limit_write_bytes_admittedcockroachdb.kv.tenant_rate_limit.write_bytes_admitted.countNumber of write bytes admitted by the rate limitercockroachdb
kv_tenant_rate_limit_write_requests_admittedcockroachdb.kv.tenant_rate_limit.write_requests_admitted.countNumber of write requests admitted by the rate limitercockroachdb
kvadmission_flow_controller_elastic_blocked_stream_countcockroachdb.kvadmission.flow_controller.elastic_blocked_stream_countNumber of replication streams with no flow tokens available for elastic requestscockroachdb
kvadmission_flow_controller_elastic_requests_admittedcockroachdb.kvadmission.flow_controller.elastic_requests_admitted.countNumber of elastic requests admitted by the flow controllercockroachdb
kvadmission_flow_controller_elastic_requests_bypassedcockroachdb.kvadmission.flow_controller.elastic_requests_bypassed.countNumber of elastic waiting requests that bypassed the flow controller due to disconnecting streamscockroachdb
kvadmission_flow_controller_elastic_requests_erroredcockroachdb.kvadmission.flow_controller.elastic_requests_errored.countNumber of elastic requests that errored out while waiting for flow tokenscockroachdb
kvadmission_flow_controller_elastic_requests_waitingcockroachdb.kvadmission.flow_controller.elastic_requests_waitingNumber of elastic requests waiting for flow tokenscockroachdb
kvadmission_flow_controller_elastic_stream_countcockroachdb.kvadmission.flow_controller.elastic_stream_countTotal number of replication streams for elastic requestscockroachdb
kvadmission_flow_controller_elastic_tokens_availablecockroachdb.kvadmission.flow_controller.elastic_tokens_availableFlow tokens available for elastic requests, across all replication streamscockroachdb
kvadmission_flow_controller_elastic_tokens_deductedcockroachdb.kvadmission.flow_controller.elastic_tokens_deducted.countFlow tokens deducted by elastic requests, across all replication streamscockroachdb
kvadmission_flow_controller_elastic_tokens_returnedcockroachdb.kvadmission.flow_controller.elastic_tokens_returned.countFlow tokens returned by elastic requests, across all replication streamscockroachdb
kvadmission_flow_controller_elastic_tokens_unaccountedcockroachdb.kvadmission.flow_controller.elastic_tokens_unaccounted.countFlow tokens returned by elastic requests that were unaccounted for, across all replication streamscockroachdb
kvadmission_flow_controller_elastic_wait_durationcockroachdb.kvadmission.flow_controller.elastic_wait_duration.countLatency histogram for time elastic requests spent waiting for flow tokenscockroachdb
kvadmission_flow_controller_regular_blocked_stream_countcockroachdb.kvadmission.flow_controller.regular_blocked_stream_countNumber of replication streams with no flow tokens available for regular requestscockroachdb
kvadmission_flow_controller_regular_requests_admittedcockroachdb.kvadmission.flow_controller.regular_requests_admitted.countNumber of regular requests admitted by the flow controllercockroachdb
kvadmission_flow_controller_regular_requests_bypassedcockroachdb.kvadmission.flow_controller.regular_requests_bypassed.countNumber of regular waiting requests that bypassed the flow controller due to disconnecting streamscockroachdb
kvadmission_flow_controller_regular_requests_erroredcockroachdb.kvadmission.flow_controller.regular_requests_errored.countNumber of regular requests that errored out while waiting for flow tokenscockroachdb
kvadmission_flow_controller_regular_requests_waitingcockroachdb.kvadmission.flow_controller.regular_requests_waitingNumber of regular requests waiting for flow tokenscockroachdb
kvadmission_flow_controller_regular_stream_countcockroachdb.kvadmission.flow_controller.regular_stream_countTotal number of replication streams for regular requestscockroachdb
kvadmission_flow_controller_regular_tokens_availablecockroachdb.kvadmission.flow_controller.regular_tokens_availableFlow tokens available for regular requests, across all replication streamscockroachdb
kvadmission_flow_controller_regular_tokens_deductedcockroachdb.kvadmission.flow_controller.regular_tokens_deducted.countFlow tokens deducted by regular requests, across all replication streamscockroachdb
kvadmission_flow_controller_regular_tokens_returnedcockroachdb.kvadmission.flow_controller.regular_tokens_returned.countFlow tokens returned by regular requests, across all replication streamscockroachdb
kvadmission_flow_controller_regular_tokens_unaccountedcockroachdb.kvadmission.flow_controller.regular_tokens_unaccounted.countFlow tokens returned by regular requests that were unaccounted for, across all replication streamscockroachdb
kvadmission_flow_controller_regular_wait_durationcockroachdb.kvadmission.flow_controller.regular_wait_duration.countLatency histogram for time regular requests spent waiting for flow tokenscockroachdb
kvadmission_flow_handle_elastic_requests_admittedcockroachdb.kvadmission.flow_handle.elastic_requests_admitted.countNumber of elastic requests admitted by the flow handlecockroachdb
kvadmission_flow_handle_elastic_requests_erroredcockroachdb.kvadmission.flow_handle.elastic_requests_errored.countNumber of elastic requests that errored out while waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_elastic_requests_waitingcockroachdb.kvadmission.flow_handle.elastic_requests_waitingNumber of elastic requests waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_elastic_wait_durationcockroachdb.kvadmission.flow_handle.elastic_wait_duration.countLatency histogram for time elastic requests spent waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_regular_requests_admittedcockroachdb.kvadmission.flow_handle.regular_requests_admitted.countNumber of regular requests admitted by the flow handlecockroachdb
kvadmission_flow_handle_regular_requests_erroredcockroachdb.kvadmission.flow_handle.regular_requests_errored.countNumber of regular requests that errored out while waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_regular_requests_waitingcockroachdb.kvadmission.flow_handle.regular_requests_waitingNumber of regular requests waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_regular_wait_durationcockroachdb.kvadmission.flow_handle.regular_wait_duration.countLatency histogram for time regular requests spent waiting for flow tokens, at the handle levelcockroachdb
kvadmission_flow_handle_streams_connectedcockroachdb.kvadmission.flow_handle.streams_connected.countNumber of times we’ve connected to a stream, at the handle levelcockroachdb
kvadmission_flow_handle_streams_disconnectedcockroachdb.kvadmission.flow_handle.streams_disconnected.countNumber of times we’ve disconnected from a stream, at the handle levelcockroachdb
kvadmission_flow_token_dispatch_coalesced_elasticcockroachdb.kvadmission.flow_token_dispatch.coalesced_elastic.countNumber of coalesced elastic flow token dispatches (where we’re informing the sender of a higher log entry being admitted)cockroachdb
kvadmission_flow_token_dispatch_coalesced_regularcockroachdb.kvadmission.flow_token_dispatch.coalesced_regular.countNumber of coalesced regular flow token dispatches (where we’re informing the sender of a higher log entry being admitted)cockroachdb
kvadmission_flow_token_dispatch_local_elasticcockroachdb.kvadmission.flow_token_dispatch.local_elastic.countNumber of local elastic flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_local_regularcockroachdb.kvadmission.flow_token_dispatch.local_regular.countNumber of local regular flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_pending_elasticcockroachdb.kvadmission.flow_token_dispatch.pending_elasticNumber of pending elastic flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_pending_nodescockroachdb.kvadmission.flow_token_dispatch.pending_nodesNumber of nodes pending flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_pending_regularcockroachdb.kvadmission.flow_token_dispatch.pending_regularNumber of pending regular flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_remote_elasticcockroachdb.kvadmission.flow_token_dispatch.remote_elastic.countNumber of remote elastic flow token dispatchescockroachdb
kvadmission_flow_token_dispatch_remote_regularcockroachdb.kvadmission.flow_token_dispatch.remote_regular.countNumber of remote regular flow token dispatchescockroachdb
leases_epochcockroachdb.leases.epochNumber of replica leaseholders using epoch-based leasescockroachdb
leases_errorcockroachdb.leases.error.countNumber of failed lease requestscockroachdb
leases_expirationcockroachdb.leases.expirationNumber of replica leaseholders using expiration-based leasescockroachdb
leases_livenesscockroachdb.leases.livenessNumber of replica leaseholders for the liveness range(s)cockroachdb
leases_preferences_less_preferredcockroachdb.leases.preferences.less_preferredNumber of replica leaseholders which satisfy a lease preference which is not the most preferredcockroachdb
leases_preferences_violatingcockroachdb.leases.preferences.violatingNumber of replica leaseholders which violate lease preferencescockroachdb
leases_requests_latencycockroachdb.leases.requests.latency.countLease request latency (all types and outcomes, coalesced)cockroachdb
leases_successcockroachdb.leases.success.countNumber of successful lease requestscockroachdb
leases_transfers_errorcockroachdb.leases.transfers.error.countNumber of failed lease transferscockroachdb
leases_transfers_successcockroachdb.leases.transfers.success.countNumber of successful lease transferscockroachdb
livebytescockroachdb.livebytesNumber of bytes of live data (keys plus values)cockroachdb
livecountcockroachdb.livecountCount of live keyscockroachdb
liveness_epochincrementscockroachdb.liveness.epochincrements.countNumber of times this node has incremented its liveness epochcockroachdb
liveness_heartbeatfailurescockroachdb.liveness.heartbeatfailures.countNumber of failed node liveness heartbeats from this nodecockroachdb
liveness_heartbeatlatencycockroachdb.liveness.heartbeatlatency.countNode liveness heartbeat latencycockroachdb
liveness_heartbeatsinflightcockroachdb.liveness.heartbeatsinflightNumber of in-flight liveness heartbeats from this nodecockroachdb
liveness_heartbeatsuccessescockroachdb.liveness.heartbeatsuccesses.countNumber of successful node liveness heartbeats from this nodecockroachdb
liveness_livenodescockroachdb.liveness.livenodesNumber of live nodes in the cluster (will be 0 if this node is not itself live)cockroachdb
lockbytescockroachdb.lockbytesNumber of bytes taken up by replicated lock key-values (shared and exclusive strength, not intent strength)cockroachdb
lockcountcockroachdb.lockcountCount of replicated locks (shared, exclusive, and intent strength)cockroachdb
log_buffered_messages_droppedcockroachdb.log.buffered.messages.dropped.countCount of log messages that are dropped by buffered log sinks. When CRDB attempts to buffer a log message in a buffered log sink whose buffer is already full, it drops the oldest buffered messages to make space for the new messagecockroachdb
log_fluent_sink_conn_errorscockroachdb.log.fluent.sink.conn.errors.countNumber of connection errors experienced by fluent-server logging sinkscockroachdb
log_messages_countcockroachdb.log.messages.countCount of messages logged on the node since startup. Note that this does not measure the fan-out of single log messages to the various configured logging sinks.cockroachdb
node_idcockroachdb.node_idnode ID with labels for advertised RPC and HTTP addressescockroachdb
physical_replication_admit_latencycockroachdb.physical_replication.admit_latency.countEvent admission latency: a difference between event MVCC timestamp and the time it was admitted into ingestion processorcockroachdb
physical_replication_commit_latencycockroachdb.physical_replication.commit_latency.countEvent commit latency: a difference between event MVCC timestamp and the time it was flushed into disk. If we batch events, then the difference between the oldest event in the batch and flush is recordedcockroachdb
physical_replication_distsql_replan_countcockroachdb.physical_replication.distsql_replan_count.countTotal number of dist sql replanning eventscockroachdb
physical_replication_events_ingestedcockroachdb.physical_replication.events_ingested.countEvents ingested by all replication jobscockroachdb
physical_replication_failover_progresscockroachdb.physical_replication.cutover_progressThe number of ranges left to revert in order to complete an inflight cutovercockroachdb
physical_replication_flush_hist_nanoscockroachdb.physical_replication.flush_hist_nanos.countTime spent flushing messages across all replication streamscockroachdb
physical_replication_flushescockroachdb.physical_replication.flushes.countTotal flushes across all replication jobscockroachdb
physical_replication_logical_bytescockroachdb.physical_replication.logical_bytes.countLogical bytes (sum of keys + values) ingested by all replication jobscockroachdb
physical_replication_replicated_time_secondscockroachdb.physical_replication.replicated_time_secondsThe replicated time of the physical replication stream in seconds since the unix epoch.cockroachdb
physical_replication_resolved_events_ingestedcockroachdb.physical_replication.resolved_events_ingested.countResolved events ingested by all replication jobscockroachdb
physical_replication_runningcockroachdb.physical_replication.runningNumber of currently running replication streamscockroachdb
queue_consistency_pendingcockroachdb.queue.consistency.pendingNumber of pending replicas in the consistency checker queuecockroachdb
queue_consistency_process_failurecockroachdb.queue.consistency.process.failure.countNumber of replicas which failed processing in the consistency checker queuecockroachdb
queue_consistency_process_successcockroachdb.queue.consistency.process.success.countNumber of replicas successfully processed by the consistency checker queuecockroachdb
queue_consistency_processingnanoscockroachdb.queue.consistency.processingnanos.countNanoseconds spent processing replicas in the consistency checker queuecockroachdb
queue_gc_info_abortspanconsideredcockroachdb.queue.gc.info.abortspanconsidered.countNumber of AbortSpan entries old enough to be considered for removalcockroachdb
queue_gc_info_abortspangcnumcockroachdb.queue.gc.info.abortspangcnum.countNumber of AbortSpan entries fit for removalcockroachdb
queue_gc_info_abortspanscannedcockroachdb.queue.gc.info.abortspanscanned.countNumber of transactions present in the AbortSpan scanned from the enginecockroachdb
queue_gc_info_clearrangefailedcockroachdb.queue.gc.info.clearrangefailed.countNumber of failed ClearRange operations during GCcockroachdb
queue_gc_info_clearrangesuccesscockroachdb.queue.gc.info.clearrangesuccess.countNumber of successful ClearRange operations during GCcockroachdb
queue_gc_info_enqueuehighprioritycockroachdb.queue.gc.info.enqueuehighpriority.countNumber of replicas enqueued for GC with high prioritycockroachdb
queue_gc_info_intentsconsideredcockroachdb.queue.gc.info.intentsconsidered.countNumber of ‘old’ intentscockroachdb
queue_gc_info_intenttxnscockroachdb.queue.gc.info.intenttxns.countNumber of associated distinct transactionscockroachdb
queue_gc_info_intenttxnscockroachdb.queue.gc.info.intenttxnsNumber of associated distinct transactionscockroachdb
queue_gc_info_numkeysaffectedcockroachdb.queue.gc.info.numkeysaffected.countNumber of keys with GC’able datacockroachdb
queue_gc_info_numrangekeysaffectedcockroachdb.queue.gc.info.numrangekeysaffected.countNumber of range keys GC’ablecockroachdb
queue_gc_info_pushtxncockroachdb.queue.gc.info.pushtxnNumber of attempted pushescockroachdb
queue_gc_info_pushtxncockroachdb.queue.gc.info.pushtxn.countNumber of attempted pushescockroachdb
queue_gc_info_resolvefailedcockroachdb.queue.gc.info.resolvefailed.countNumber of cleanup intent failures during GCcockroachdb
queue_gc_info_resolvesuccesscockroachdb.queue.gc.info.resolvesuccess.countNumber of successful intent resolutionscockroachdb
queue_gc_info_resolvetotalcockroachdb.queue.gc.info.resolvetotal.countNumber of attempted intent resolutionscockroachdb
queue_gc_info_transactionresolvefailedcockroachdb.queue.gc.info.transactionresolvefailed.countNumber of intent cleanup failures for local transactions during GCcockroachdb
queue_gc_info_transactionspangcabortedcockroachdb.queue.gc.info.transactionspangcaborted.countNumber of GC’able entries corresponding to aborted txnscockroachdb
queue_gc_info_transactionspangccommittedcockroachdb.queue.gc.info.transactionspangccommitted.countNumber of GC’able entries corresponding to committed txnscockroachdb
queue_gc_info_transactionspangcpendingcockroachdb.queue.gc.info.transactionspangcpending.countNumber of GC’able entries corresponding to pending txnscockroachdb
queue_gc_info_transactionspangcstagingcockroachdb.queue.gc.info.transactionspangcstaging.countNumber of GC’able entries corresponding to staging txnscockroachdb
queue_gc_info_transactionspanscannedcockroachdb.queue.gc.info.transactionspanscanned.countNumber of entries in transaction spans scanned from the enginecockroachdb
queue_gc_pendingcockroachdb.queue.gc.pendingNumber of pending replicas in the MVCC GC queuecockroachdb
queue_gc_process_failurecockroachdb.queue.gc.process.failure.countNumber of replicas which failed processing in the MVCC GC queuecockroachdb
queue_gc_process_successcockroachdb.queue.gc.process.success.countNumber of replicas successfully processed by the MVCC GC queuecockroachdb
queue_gc_processingnanoscockroachdb.queue.gc.processingnanos.countNanoseconds spent processing replicas in the MVCC GC queuecockroachdb
queue_merge_pendingcockroachdb.queue.merge.pendingNumber of pending replicas in the merge queuecockroachdb
queue_merge_process_failurecockroachdb.queue.merge.process.failure.countNumber of replicas which failed processing in the merge queuecockroachdb
queue_merge_process_successcockroachdb.queue.merge.process.success.countNumber of replicas successfully processed by the merge queuecockroachdb
queue_merge_processingnanoscockroachdb.queue.merge.processingnanos.countNanoseconds spent processing replicas in the merge queuecockroachdb
queue_merge_purgatorycockroachdb.queue.merge.purgatoryNumber of replicas in the merge queue’s purgatory, waiting to become mergeablecockroachdb
queue_raftlog_pendingcockroachdb.queue.raftlog.pendingNumber of pending replicas in the Raft log queuecockroachdb
queue_raftlog_process_failurecockroachdb.queue.raftlog.process.failure.countNumber of replicas which failed processing in the Raft log queuecockroachdb
queue_raftlog_process_successcockroachdb.queue.raftlog.process.success.countNumber of replicas successfully processed by the Raft log queuecockroachdb
queue_raftlog_processingnanoscockroachdb.queue.raftlog.processingnanos.countNanoseconds spent processing replicas in the Raft log queuecockroachdb
queue_raftsnapshot_pendingcockroachdb.queue.raftsnapshot.pendingNumber of pending replicas in the Raft repair queuecockroachdb
queue_raftsnapshot_process_failurecockroachdb.queue.raftsnapshot.process.failure.countNumber of replicas which failed processing in the Raft repair queuecockroachdb
queue_raftsnapshot_process_successcockroachdb.queue.raftsnapshot.process.success.countNumber of replicas successfully processed by the Raft repair queuecockroachdb
queue_raftsnapshot_processingnanoscockroachdb.queue.raftsnapshot.processingnanos.countNanoseconds spent processing replicas in the Raft repair queuecockroachdb
queue_replicagc_pendingcockroachdb.queue.replicagc.pendingNumber of pending replicas in the replica GC queuecockroachdb
queue_replicagc_process_failurecockroachdb.queue.replicagc.process.failure.countNumber of replicas which failed processing in the replica GC queuecockroachdb
queue_replicagc_process_successcockroachdb.queue.replicagc.process.success.countNumber of replicas successfully processed by the replica GC queuecockroachdb
queue_replicagc_processingnanoscockroachdb.queue.replicagc.processingnanos.countNanoseconds spent processing replicas in the replica GC queuecockroachdb
queue_replicagc_removereplicacockroachdb.queue.replicagc.removereplica.countNumber of replica removals attempted by the replica GC queuecockroachdb
queue_replicate_addnonvoterreplicacockroachdb.queue.replicate.addnonvoterreplica.countNumber of non-voter replica additions attempted by the replicate queuecockroachdb
queue_replicate_addreplicacockroachdb.queue.replicate.addreplica.countNumber of replica additions attempted by the replicate queuecockroachdb
queue_replicate_addreplica_errorcockroachdb.queue.replicate.addreplica.error.countNumber of failed replica additions processed by the replicate queuecockroachdb
queue_replicate_addreplica_successcockroachdb.queue.replicate.addreplica.success.countNumber of successful replica additions processed by the replicate queuecockroachdb
queue_replicate_addvoterreplicacockroachdb.queue.replicate.addvoterreplica.countNumber of voter replica additions attempted by the replicate queuecockroachdb
queue_replicate_nonvoterpromotionscockroachdb.queue.replicate.nonvoterpromotions.countNumber of non-voters promoted to voters by the replicate queuecockroachdb
queue_replicate_pendingcockroachdb.queue.replicate.pendingNumber of pending replicas in the replicate queuecockroachdb
queue_replicate_process_failurecockroachdb.queue.replicate.process.failure.countNumber of replicas which failed processing in the replicate queuecockroachdb
queue_replicate_process_successcockroachdb.queue.replicate.process.success.countNumber of replicas successfully processed by the replicate queuecockroachdb
queue_replicate_processingnanoscockroachdb.queue.replicate.processingnanos.countNanoseconds spent processing replicas in the replicate queuecockroachdb
queue_replicate_purgatorycockroachdb.queue.replicate.purgatoryNumber of replicas in the replicate queue’s purgatory, awaiting allocation optionscockroachdb
queue_replicate_rebalancenonvoterreplicacockroachdb.queue.replicate.rebalancenonvoterreplica.countNumber of non-voter replica rebalancer-initiated additions attempted by the replicate queuecockroachdb
queue_replicate_rebalancereplicacockroachdb.queue.replicate.rebalancereplica.countNumber of replica rebalancer-initiated additions attempted by the replicate queuecockroachdb
queue_replicate_rebalancevoterreplicacockroachdb.queue.replicate.rebalancevoterreplica.countNumber of voter replica rebalancer-initiated additions attempted by the replicate queuecockroachdb
queue_replicate_removedeadnonvoterreplicacockroachdb.queue.replicate.removedeadnonvoterreplica.countNumber of dead non-voter replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removedeadreplicacockroachdb.queue.replicate.removedeadreplica.countNumber of dead replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removedeadreplica_errorcockroachdb.queue.replicate.removedeadreplica.error.countNumber of failed dead replica removals processed by the replicate queuecockroachdb
queue_replicate_removedeadreplica_successcockroachdb.queue.replicate.removedeadreplica.success.countNumber of successful dead replica removals processed by the replicate queuecockroachdb
queue_replicate_removedeadvoterreplicacockroachdb.queue.replicate.removedeadvoterreplica.countNumber of dead voter replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removedecommissioningnonvoterreplicacockroachdb.queue.replicate.removedecommissioningnonvoterreplica.countNumber of decommissioning non-voter replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removedecommissioningreplicacockroachdb.queue.replicate.removedecommissioningreplica.countNumber of decommissioning replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removedecommissioningreplica_errorcockroachdb.queue.replicate.removedecommissioningreplica.error.countNumber of failed decommissioning replica removals processed by the replicate queuecockroachdb
queue_replicate_removedecommissioningreplica_successcockroachdb.queue.replicate.removedecommissioningreplica.success.countNumber of successful decommissioning replica removals processed by the replicate queuecockroachdb
queue_replicate_removedecommissioningvoterreplicacockroachdb.queue.replicate.removedecommissioningvoterreplica.countNumber of decommissioning voter replica removals attempted by the replicate queue (typically in response to a node outage)cockroachdb
queue_replicate_removelearnerreplicacockroachdb.queue.replicate.removelearnerreplica.countNumber of learner replica removals attempted by the replicate queue (typically due to internal race conditions)cockroachdb
queue_replicate_removenonvoterreplicacockroachdb.queue.replicate.removenonvoterreplica.countNumber of non-voter replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition)cockroachdb
queue_replicate_removereplicacockroachdb.queue.replicate.removereplica.countNumber of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition)cockroachdb
queue_replicate_removereplica_errorcockroachdb.queue.replicate.removereplica.error.countNumber of failed replica removals processed by the replicate queuecockroachdb
queue_replicate_removereplica_successcockroachdb.queue.replicate.removereplica.success.countNumber of successful replica removals processed by the replicate queuecockroachdb
queue_replicate_removevoterreplicacockroachdb.queue.replicate.removevoterreplica.countNumber of voter replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition)cockroachdb
queue_replicate_replacedeadreplica_errorcockroachdb.queue.replicate.replacedeadreplica.error.countNumber of failed dead replica replacements processed by the replicate queuecockroachdb
queue_replicate_replacedeadreplica_successcockroachdb.queue.replicate.replacedeadreplica.success.countNumber of successful dead replica replacements processed by the replicate queuecockroachdb
queue_replicate_replacedecommissioningreplica_errorcockroachdb.queue.replicate.replacedecommissioningreplica.error.countNumber of failed decommissioning replica replacements processed by the replicate queuecockroachdb
queue_replicate_replacedecommissioningreplica_successcockroachdb.queue.replicate.replacedecommissioningreplica.success.countNumber of successful decommissioning replica replacements processed by the replicate queuecockroachdb
queue_replicate_transferleasecockroachdb.queue.replicate.transferlease.countNumber of range lease transfers attempted by the replicate queuecockroachdb
queue_replicate_voterdemotionscockroachdb.queue.replicate.voterdemotions.countNumber of voters demoted to non-voters by the replicate queuecockroachdb
queue_split_load_basedcockroachdb.queue.split.load_based.countNumber of range splits due to a range being greater than the configured max range loadcockroachdb
queue_split_process_failurecockroachdb.queue.split.process.failure.countNumber of replicas which failed processing in the split queuecockroachdb
queue_split_process_successcockroachdb.queue.split.process.success.countNumber of replicas successfully processed by the split queuecockroachdb
queue_split_processingnanoscockroachdb.queue.split.processingnanos.countNanoseconds spent processing replicas in the split queuecockroachdb
queue_split_purgatorycockroachdb.queue.split.purgatoryNumber of replicas in the split queue’s purgatory, waiting to become splittablecockroachdb
queue_split_size_basedcockroachdb.queue.split.size_based.countNumber of range splits due to a range being greater than the configured max range sizecockroachdb
queue_split_span_config_basedcockroachdb.queue.split.span_config_based.countNumber of range splits due to span configurationcockroachdb
queue_tsmaintenance_pendingcockroachdb.queue.tsmaintenance.pendingNumber of pending replicas in the time series maintenance queuecockroachdb
queue_tsmaintenance_process_failurecockroachdb.queue.tsmaintenance.process.failure.countNumber of replicas which failed processing in the time series maintenance queuecockroachdb
queue_tsmaintenance_process_successcockroachdb.queue.tsmaintenance.process.success.countNumber of replicas successfully processed by the time series maintenance queuecockroachdb
queue_tsmaintenance_processingnanoscockroachdb.queue.tsmaintenance.processingnanos.countNanoseconds spent processing replicas in the time series maintenance queuecockroachdb
raft_commands_proposedcockroachdb.raft.commands.proposed.countNumber of Raft commands proposed. The number of proposals and all kinds of reproposals made by leaseholders. This metric approximates the number of commands submitted through Raft.cockroachdb
raft_commands_reproposed_new_laicockroachdb.raft.commands.reproposed.new_lai.countNumber of Raft commands re-proposed with a newer LAI. The number of Raft commands that leaseholders re-proposed with a modified LAI. Such re-proposals happen for commands that are committed to Raft out of intended order, and hence can not be applied as is.cockroachdb
raft_commands_reproposed_unchangedcockroachdb.raft.commands.reproposed.unchanged.countNumber of Raft commands re-proposed without modification. The number of Raft commands that leaseholders re-proposed without modification. Such re-proposals happen for commands that are not committed/applied within a timeout, and have a high chance of being dropped.cockroachdb
raft_commandsappliedcockroachdb.raft.commandsapplied.countNumber of Raft commands applied. This measurement is taken on the Raft apply loops of all Replicas (leaders and followers alike), meaning that it does not measure the number of Raft commands proposed (in the hypothetical extreme case, all Replicas may apply all commands through snapshots, thus not increasing this metric at all). Instead, it is a proxy for how much work is being done advancing the Replica state machines on this node.cockroachdb
raft_droppedcockroachdb.raft.dropped.countNumber of Raft proposals dropped (this counts individial raftpb.Entry, not raftpb.MsgProp)cockroachdb
raft_dropped_leadercockroachdb.raft.dropped_leader.countNumber of Raft proposals dropped by a Replica that believes itself to be the leader; each update also increments raft.dropped (this counts individial raftpb.Entry, not raftpb.MsgProp)cockroachdb
raft_entrycache_accessescockroachdb.raft.entrycache.accesses.countNumber of cache lookups in the Raft entry cachecockroachdb
raft_entrycache_bytescockroachdb.raft.entrycache.bytesAggregate size of all Raft entries in the Raft entry cachecockroachdb
raft_entrycache_hitscockroachdb.raft.entrycache.hits.countNumber of successful cache lookups in the Raft entry cachecockroachdb
raft_entrycache_read_bytescockroachdb.raft.entrycache.read_bytes.countCounter of bytes in entries returned from the Raft entry cachecockroachdb
raft_entrycache_sizecockroachdb.raft.entrycache.sizeNumber of Raft entries in the Raft entry cachecockroachdb
raft_heartbeats_pendingcockroachdb.raft.heartbeats.pendingNumber of pending heartbeats and responses waiting to be coalescedcockroachdb
raft_process_applycommitted_latencycockroachdb.raft.process.applycommitted.latency.countLatency histogram for applying all committed Raft commands in a Raft ready. This measures the end-to-end latency of applying all commands in a Raft ready. Note that this closes over possibly multiple measurements of the ‘raft.process.commandcommit.latency’ metric, which receives datapoints for each sub-batch processed in the process.cockroachdb
raft_process_commandcommit_latencycockroachdb.raft.process.commandcommit.latency.countLatency histogram for applying a batch of Raft commands to the state machine. This metric is misnamed: it measures the latency for applying a batch of committed Raft commands to a Replica state machine. This requires only non-durable I/O (except for replication configuration changes). Note that a “batch” in this context is really a sub-batch of the batch received for application during raft ready handling. The ‘raft.process.applycommitted.latency’ histogram is likely more suitable in most cases, as it measures the total latency across all sub-batches (i.e. the sum of commandcommit.latency for a complete batch).cockroachdb
raft_process_handleready_latencycockroachdb.raft.process.handleready.latency.countLatency histogram for handling a Raft ready. This measures the end-to-end-latency of the Raft state advancement loop, including: - snapshot application - SST ingestion - durably appending to the Raft log (i.e. includes fsync) - entry application (incl. replicated side effects, notably log truncation) These include work measured in ‘raft.process.commandcommit.latency’ and ‘raft.process.applycommitted.latency’. However, matching percentiles of these metrics may be higher than handleready, since not every handleready cycle leads to an update of the others. For example, under tpcc-100 on a single node, the handleready count is approximately twice the logcommit count (and logcommit count tracks closely with applycommitted count). High percentile outliers can be caused by individual large Raft commands or storage layer blips. Lower percentile (e.g. 50th) increases are often driven by CPU exhaustion or storage layer slowdowns.cockroachdb
raft_process_logcommit_latencycockroachdb.raft.process.logcommit.latency.countLatency histogram for committing Raft log entries to stable storage This measures the latency of durably committing a group of newly received Raft entries as well as the HardState entry to disk. This excludes any data processing, i.e. we measure purely the commit latency of the resulting Engine write. Homogeneous bands of p50-p99 latencies (in the presence of regular Raft traffic), make it likely that the storage layer is healthy. Spikes in the latency bands can either hint at the presence of large sets of Raft entries being received, or at performance issues at the storage layer.cockroachdb
raft_process_tickingnanoscockroachdb.raft.process.tickingnanos.countNanoseconds spent in store.processRaft() processing replica.Tick()cockroachdb
raft_process_workingnanoscockroachdb.raft.process.workingnanos.countNanoseconds spent in store.processRaft() working. This is the sum of the measurements passed to the raft.process.handleready.latency histogram.cockroachdb
raft_quota_pool_percent_usedcockroachdb.raft.quota_pool.percent_used.countHistogram of proposal quota pool utilization (0-100) per leaseholder per metrics intervalcockroachdb
raft_rcvd_appcockroachdb.raft.rcvd.app.countNumber of MsgApp messages received by this storecockroachdb
raft_rcvd_apprespcockroachdb.raft.rcvd.appresp.countNumber of MsgAppResp messages received by this storecockroachdb
raft_rcvd_bytescockroachdb.raft.rcvd.bytes.countNumber of bytes in Raft messages received by this store. Note that this does not include raft snapshot received.cockroachdb
raft_rcvd_cross_region_bytescockroachdb.raft.rcvd.cross_region.bytes.countNumber of bytes received by this store for cross region Raft messages (when region tiers are configured). Note that this does not include raft snapshot received.cockroachdb
raft_rcvd_cross_zone_bytescockroachdb.raft.rcvd.cross_zone.bytes.countNumber of bytes received by this store for cross zone, same region Raft messages (when region and zone tiers are configured). If region tiers are not configured, this count may include data sent between different regions. To ensure accurate monitoring of transmitted data, it is important to set up a consistent locality configuration across nodes. Note that this does not include raft snapshot received.cockroachdb
raft_rcvd_droppedcockroachdb.raft.rcvd.dropped.countNumber of incoming Raft messages dropped (due to queue length or size)cockroachdb
raft_rcvd_dropped_bytescockroachdb.raft.rcvd.dropped_bytes.countBytes of dropped incoming Raft messagescockroachdb
raft_rcvd_heartbeatcockroachdb.raft.rcvd.heartbeat.countNumber of (coalesced, if enabled) MsgHeartbeat messages received by this storecockroachdb
raft_rcvd_heartbeatrespcockroachdb.raft.rcvd.heartbeatresp.countNumber of (coalesced, if enabled) MsgHeartbeatResp messages received by this storecockroachdb
raft_rcvd_prevotecockroachdb.raft.rcvd.prevote.countNumber of MsgPreVote messages received by this storecockroachdb
raft_rcvd_prevoterespcockroachdb.raft.rcvd.prevoteresp.countNumber of MsgPreVoteResp messages received by this storecockroachdb
raft_rcvd_propcockroachdb.raft.rcvd.prop.countNumber of MsgProp messages received by this storecockroachdb
raft_rcvd_queued_bytescockroachdb.raft.rcvd.queued_bytesNumber of bytes in messages currently waiting for raft processingcockroachdb
raft_rcvd_snapcockroachdb.raft.rcvd.snap.countNumber of MsgSnap messages received by this storecockroachdb
raft_rcvd_stepped_bytescockroachdb.raft.rcvd.stepped_bytes.countNumber of bytes in messages processed by Raft. Messages reflected here have been handed to Raft (via RawNode.Step). This does not imply that the messages are no longer held in memory or that IO has been performed. Raft delegates IO activity to Raft ready handling, which occurs asynchronously. Since handing messages to Raft serializes with Raft ready handling and size the size of an entry is dominated by the contained pebble WriteBatch, on average the rate at which this metric increases is a good proxy for the rate at which Raft ready handling consumes writes.cockroachdb
raft_rcvd_timeoutnowcockroachdb.raft.rcvd.timeoutnow.countNumber of MsgTimeoutNow messages received by this storecockroachdb
raft_rcvd_transferleadercockroachdb.raft.rcvd.transferleader.countNumber of MsgTransferLeader messages received by this storecockroachdb
raft_rcvd_votecockroachdb.raft.rcvd.vote.countNumber of MsgVote messages received by this storecockroachdb
raft_rcvd_voterespcockroachdb.raft.rcvd.voteresp.countNumber of MsgVoteResp messages received by this storecockroachdb
raft_replication_latencycockroachdb.raft.replication.latency.countThe duration elapsed between having evaluated a BatchRequest and it being reflected in the proposer’s state machine (i.e. having applied fully). This encompasses time spent in the quota pool, in replication (including reproposals), and application, but notably not sequencing latency (i.e. contention and latch acquisition). No measurement is recorded for read-only commands as well as read-write commands which end up not writing (such as a DeleteRange on an empty span). Commands that result in ‘above-replication’ errors (i.e. txn retries, etc) are similarly excluded. Errors that arise while waiting for the in-flight replication result or result from application of the command are included. Note also that usually, clients are signalled at beginning of application, but the recorded measurement captures the entirety of log application. The duration is always measured on the proposer, even if the Raft leader and leaseholder are not colocated, or the request is proposed from a follower. Commands that use async consensus will still cause a measurement that reflects the actual replication latency, despite returning early to the client.cockroachdb
raft_scheduler_latencycockroachdb.raft.scheduler.latency.countQueueing durations for ranges waiting to be processed by the Raft scheduler. This histogram measures the delay from when a range is registered with the scheduler for processing to when it is actually processed. This does not include the duration of processing.cockroachdb
raft_scheduler_latencycockroachdb.raft.scheduler.latencyQueueing durations for ranges waiting to be processed by the Raft scheduler. This histogram measures the delay from when a range is registered with the scheduler for processing to when it is actually processed. This does not include the duration of processing.cockroachdb
raft_sent_bytescockroachdb.raft.sent.bytes.countNumber of bytes in Raft messages sent by this store. Note that this does not include raft snapshot sent.cockroachdb
raft_sent_cross_region_bytescockroachdb.raft.sent.cross_region.bytes.countNumber of bytes sent by this store for cross region Raft messages (when region tiers are configured). Note that this does not include raft snapshot sent.cockroachdb
raft_sent_cross_zone_bytescockroachdb.raft.sent.cross_zone.bytes.countNumber of bytes sent by this store for cross zone, same region Raft messages (when region and zone tiers are configured). If region tiers are not configured, this count may include data sent between different regions. To ensure accurate monitoring of transmitted data, it is important to set up a consistent locality configuration across nodes. Note that this does not include raft snapshot sent.cockroachdb
raft_storage_read_bytescockroachdb.raft.storage.read_bytes.countCounter of raftpb.Entry.Size() read from pebble for raft log entries. These are the bytes returned from the (raft.Storage).Entries method that were not returned via the raft entry cache. This metric plus the raft.entrycache.read_bytes metric represent the total bytes returned from the Entries method. Since pebble might serve these entries from the block cache, only a fraction of this throughput might manifest in disk metrics. Entries tracked in this metric incur an unmarshalling-related CPU and memory overhead that would not be incurred would the entries be served from the raft entry cache. The bytes returned here do not correspond 1:1 to bytes read from pebble. This metric measures the in-memory size of the raftpb.Entry, whereas we read its encoded representation from pebble. As there is no compression involved, these will generally be comparable. A common reason for elevated measurements on this metric is that a store is falling behind on raft log application. The raft entry cache generally tracks entries that were recently appended, so if log application falls behind the cache will already have moved on to newer entries.cockroachdb
raft_tickscockroachdb.raft.ticks.countNumber of Raft ticks queuedcockroachdb
raft_timeoutcampaigncockroachdb.raft.timeoutcampaign.countNumber of Raft replicas campaigning after missed heartbeats from leadercockroachdb
raft_transport_flow_token_dispatches_droppedcockroachdb.raft.transport.flow_token_dispatches_dropped.countNumber of flow token dispatches dropped by the Raft Transportcockroachdb
raft_transport_rcvdcockroachdb.raft.transport.rcvd.countNumber of Raft messages received by the Raft Transportcockroachdb
raft_transport_reverse_rcvdcockroachdb.raft.transport.reverse_rcvd.countMessages received from the reverse direction of a stream. These messages should be rare. They are mostly informational, and are not actual responses to Raft messages. Responses are received over another stream.cockroachdb
raft_transport_reverse_sentcockroachdb.raft.transport.reverse_sent.countMessages sent in the reverse direction of a stream. These messages should be rare. They are mostly informational, and are not actual responses to Raft messages. Responses are sent over another stream.cockroachdb
raft_transport_send_queue_bytescockroachdb.raft.transport.send_queue_bytesThe total byte size of pending outgoing messages in the queue. The queue is composed of multiple bounded channels associated with different peers. A size higher than the average baseline could indicate issues streaming messages to at least one peer. Use this metric together with send-queue-size, to have a fuller picture.cockroachdb
raft_transport_send_queue_sizecockroachdb.raft.transport.send_queue_sizeNumber of pending outgoing messages in the Raft Transport queue. The queue is composed of multiple bounded channels associated with different peers. The overall size of tens of thousands could indicate issues streaming messages to at least one peer. Use this metric in conjunction with send-queue-bytes.cockroachdb
raft_transport_sends_droppedcockroachdb.raft.transport.sends_dropped.countNumber of Raft message sends dropped by the Raft Transportcockroachdb
raft_transport_sentcockroachdb.raft.transport.sent.countNumber of Raft messages sent by the Raft Transportcockroachdb
raftlog_behindcockroachdb.raftlog.behindNumber of Raft log entries followers on other stores are behind. This gauge provides a view of the aggregate number of log entries the Raft leaders on this node think the followers are behind. Since a raft leader may not always have a good estimate for this information for all of its followers, and since followers are expected to be behind (when they are not required as part of a quorum) and the aggregate thus scales like the count of such followers, it is difficult to meaningfully interpret this metric.cockroachdb
raftlog_truncatedcockroachdb.raftlog.truncated.countNumber of Raft log entries truncatedcockroachdb
range_addscockroachdb.range.adds.countNumber of range additionscockroachdb
range_mergescockroachdb.range.merges.countNumber of range mergescockroachdb
range_raftleaderremovalscockroachdb.range.raftleaderremovals.countNumber of times the current Raft leader was removed from a rangecockroachdb
range_raftleadertransferscockroachdb.range.raftleadertransfers.countNumber of raft leader transferscockroachdb
range_recoveriescockroachdb.range.recoveries.countCount of offline loss of quorum recovery operations performed on ranges. This count increments for every range recovered in offline loss of quorum recovery operation. Metric is updated when node on which survivor replica is located starts following the recovery.cockroachdb
range_removescockroachdb.range.removes.countNumber of range removalscockroachdb
range_snapshots_applied_initialcockroachdb.range.snapshots.applied_initial.countNumber of snapshots applied for initial upreplicationcockroachdb
range_snapshots_applied_non_votercockroachdb.range.snapshots.applied_non_voter.countNumber of snapshots applied by non-voter replicascockroachdb
range_snapshots_applied_votercockroachdb.range.snapshots.applied_voter.countNumber of snapshots applied by voter replicascockroachdb
range_snapshots_cross_region_rcvd_bytescockroachdb.range.snapshots.cross_region.rcvd_bytes.countNumber of snapshot bytes received cross regioncockroachdb
range_snapshots_cross_region_sent_bytescockroachdb.range.snapshots.cross_region.sent_bytes.countNumber of snapshot bytes sent cross regioncockroachdb
range_snapshots_cross_zone_rcvd_bytescockroachdb.range.snapshots.cross_zone.rcvd_bytes.countNumber of snapshot bytes received cross zone within same region or if region tiers are not configured. This count increases for each snapshot received between different zones within the same region. However, if the region tiers are not configured, this count may also include snapshot data received between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
range_snapshots_cross_zone_sent_bytescockroachdb.range.snapshots.cross_zone.sent_bytes.countNumber of snapshot bytes sent cross zone within same region or if region tiers are not configured. This count increases for each snapshot sent between different zones within the same region. However, if the region tiers are not configured, this count may also include snapshot data sent between different regions. Ensuring consistent configuration of region and zone tiers across nodes helps to accurately monitor the data transmitted.cockroachdb
range_snapshots_delegate_failurescockroachdb.range.snapshots.delegate.failures.countNumber of snapshots that were delegated to a different node and resulted in failure on that delegate. There are numerous reasons a failure can occur on a delegate such as timeout, the delegate Raft log being too far behind or the delegate being too busy to send.cockroachdb
range_snapshots_delegate_in_progresscockroachdb.range.snapshots.delegate.in_progressNumber of delegated snapshots that are currently in-flight.cockroachdb
range_snapshots_delegate_sent_bytescockroachdb.range.snapshots.delegate.sent_bytes.countBytes sent using a delegate. The number of bytes sent as a result of a delegate snapshot request that was originated from a different node. This metric is useful in evaluating the network savings of not sending cross region traffic.cockroachdb
range_snapshots_delegate_successescockroachdb.range.snapshots.delegate.successes.countNumber of snapshots that were delegated to a different node and resulted in success on that delegate. This does not count self delegated snapshots.cockroachdb
range_snapshots_generatedcockroachdb.range.snapshots.generated.countNumber of generated snapshotscockroachdb
range_snapshots_rcvd_bytescockroachdb.range.snapshots.rcvd_bytes.countNumber of snapshot bytes receivedcockroachdb
range_snapshots_rebalancing_rcvd_bytescockroachdb.range.snapshots.rebalancing.rcvd_bytes.countNumber of rebalancing snapshot bytes receivedcockroachdb
range_snapshots_rebalancing_sent_bytescockroachdb.range.snapshots.rebalancing.sent_bytes.countNumber of rebalancing snapshot bytes sentcockroachdb
range_snapshots_recovery_rcvd_bytescockroachdb.range.snapshots.recovery.rcvd_bytes.countNumber of raft recovery snapshot bytes receivedcockroachdb
range_snapshots_recovery_sent_bytescockroachdb.range.snapshots.recovery.sent_bytes.countNumber of raft recovery snapshot bytes sentcockroachdb
range_snapshots_recv_failedcockroachdb.range.snapshots.recv_failed.countNumber of range snapshot initialization messages that errored out on the recipient, typically before any data is transferredcockroachdb
range_snapshots_recv_in_progresscockroachdb.range.snapshots.recv_in_progressNumber of non-empty snapshots being receivedcockroachdb
range_snapshots_recv_queuecockroachdb.range.snapshots.recv_queueNumber of snapshots queued to receivecockroachdb
range_snapshots_recv_queue_bytescockroachdb.range.snapshots.recv_queue_bytesTotal size of all snapshots in the snapshot receive queuecockroachdb
range_snapshots_recv_total_in_progresscockroachdb.range.snapshots.recv_total_in_progressNumber of total snapshots being receivedcockroachdb
range_snapshots_recv_unusablecockroachdb.range.snapshots.recv_unusable.countNumber of range snapshot that were fully transmitted but determined to be unnecessary or unusablecockroachdb
range_snapshots_send_in_progresscockroachdb.range.snapshots.send_in_progressNumber of non-empty snapshots being sentcockroachdb
range_snapshots_send_queuecockroachdb.range.snapshots.send_queueNumber of snapshots queued to sendcockroachdb
range_snapshots_send_queue_bytescockroachdb.range.snapshots.send_queue_bytesTotal size of all snapshots in the snapshot send queuecockroachdb
range_snapshots_send_total_in_progresscockroachdb.range.snapshots.send_total_in_progressNumber of total snapshots being sentcockroachdb
range_snapshots_sent_bytescockroachdb.range.snapshots.sent_bytes.countNumber of snapshot bytes sentcockroachdb
range_snapshots_unknown_rcvd_bytescockroachdb.range.snapshots.unknown.rcvd_bytes.countNumber of unknown snapshot bytes receivedcockroachdb
range_snapshots_unknown_sent_bytescockroachdb.range.snapshots.unknown.sent_bytes.countNumber of unknown snapshot bytes sentcockroachdb
range_splitscockroachdb.range.splits.countNumber of range splitscockroachdb
rangekeybytescockroachdb.rangekeybytesNumber of bytes taken up by range keys (e.g. MVCC range tombstones)cockroachdb
rangekeycountcockroachdb.rangekeycountCount of all range keys (e.g. MVCC range tombstones)cockroachdb
rangescockroachdb.rangesNumber of rangescockroachdb
ranges_overreplicatedcockroachdb.ranges.overreplicatedNumber of ranges with more live replicas than the replication targetcockroachdb
ranges_unavailablecockroachdb.ranges.unavailableNumber of ranges with fewer live replicas than needed for quorumcockroachdb
ranges_underreplicatedcockroachdb.ranges.underreplicatedNumber of ranges with fewer live replicas than the replication targetcockroachdb
rangevalbytescockroachdb.rangevalbytesNumber of bytes taken up by range key values (e.g. MVCC range tombstones)cockroachdb
rangevalcountcockroachdb.rangevalcountCount of all range key values (e.g. MVCC range tombstones)cockroachdb
rebalancing_cpunanospersecondcockroachdb.rebalancing.cpunanospersecondAverage CPU nanoseconds spent on processing replica operations in the last 30 minutes.cockroachdb
rebalancing_lease_transferscockroachdb.rebalancing.lease.transfers.countNumber of lease transfers motivated by store-level load imbalancescockroachdb
rebalancing_queriespersecondcockroachdb.rebalancing.queriespersecondNumber of kv-level requests received per second by the store, considering the last 30 minutes, as used in rebalancing decisions.cockroachdb
rebalancing_range_rebalancescockroachdb.rebalancing.range.rebalances.countNumber of range rebalance operations motivated by store-level load imbalancescockroachdb
rebalancing_readbytespersecondcockroachdb.rebalancing.readbytespersecondNumber of bytes read recently per second, considering the last 30 minutes.cockroachdb
rebalancing_readspersecondcockroachdb.rebalancing.readspersecondNumber of keys read recently per second, considering the last 30 minutes.cockroachdb
rebalancing_replicas_cpunanospersecondcockroachdb.rebalancing.replicas.cpunanospersecond.countHistogram of average CPU nanoseconds spent on processing replica operations in the last 30 minutes.cockroachdb
rebalancing_replicas_queriespersecondcockroachdb.rebalancing.replicas.queriespersecond.countHistogram of average kv-level requests received per second by replicas on the store in the last 30 minutes.cockroachdb
rebalancing_requestspersecondcockroachdb.rebalancing.requestspersecondNumber of requests received recently per second, considering the last 30 minutes.cockroachdb
rebalancing_state_imbalanced_overfull_options_exhaustedcockroachdb.rebalancing.state.imbalanced_overfull_options_exhausted.countNumber of occurrences where this store was overfull but failed to shed load after exhausting available rebalance optionscockroachdb
rebalancing_writebytespersecondcockroachdb.rebalancing.writebytespersecondNumber of bytes written recently per second, considering the last 30 minutes.cockroachdb
rebalancing_writespersecondcockroachdb.rebalancing.writespersecondNumber of keys written (i.e. applied by raft) per second to the store, considering the last 30 minutes.cockroachdb
replicascockroachdb.replicasNumber of replicascockroachdb
replicas_leaderscockroachdb.replicas.leadersNumber of raft leaderscockroachdb
replicas_leaders_invalid_leasecockroachdb.replicas.leaders_invalid_leaseNumber of replicas that are Raft leaders whose lease is invalidcockroachdb
replicas_leaders_not_leaseholderscockroachdb.replicas.leaders_not_leaseholdersNumber of replicas that are Raft leaders whose range lease is held by another storecockroachdb
replicas_leaseholderscockroachdb.replicas.leaseholdersNumber of lease holderscockroachdb
replicas_quiescentcockroachdb.replicas.quiescentNumber of quiesced replicascockroachdb
replicas_reservedcockroachdb.replicas.reservedNumber of replicas reserved for snapshotscockroachdb
replicas_uninitializedcockroachdb.replicas.uninitializedNumber of uninitialized replicas, this does not include uninitialized replicas that can lie dormant in a persistent state.cockroachdb
requests_backpressure_splitcockroachdb.requests.backpressure.splitNumber of backpressured writes waiting on a Range split. A Range will backpressure (roughly) non-system traffic when the range is above the configured size until the range splits. When the rate of this metric is nonzero over extended periods of time, it should be investigated why splits are not occurring.cockroachdb
requests_slow_distsendercockroachdb.requests.slow.distsenderNumber of range-bound RPCs currently stuck or retrying for a long time. Note that this is not a good signal for KV health. The remote side of the RPCs tracked here may experience contention, so an end user can easily cause values for this metric to be emitted by leaving a transaction open for a long time and contending with it using a second transaction.cockroachdb
requests_slow_latchcockroachdb.requests.slow.latchNumber of requests that have been stuck for a long time acquiring latches. Latches moderate access to the KV keyspace for the purpose of evaluating and replicating commands. A slow latch acquisition attempt is often caused by another request holding and not releasing its latches in a timely manner. This in turn can either be caused by a long delay in evaluation (for example, under severe system overload) or by delays at the replication layer. This gauge registering a nonzero value usually indicates a serious problem and should be investigated.cockroachdb
requests_slow_leasecockroachdb.requests.slow.leaseNumber of requests that have been stuck for a long time acquiring a lease. This gauge registering a nonzero value usually indicates range or replica unavailability, and should be investigated. In the common case, we also expect to see ‘requests.slow.raft’ to register a nonzero value, indicating that the lease requests are not getting a timely response from the replication layer.cockroachdb
requests_slow_raftcockroachdb.requests.slow.raftNumber of requests that have been stuck for a long time in the replication layer. An (evaluated) request has to pass through the replication layer, notably the quota pool and raft. If it fails to do so within a highly permissive duration, the gauge is incremented (and decremented again once the request is either applied or returns an error). A nonzero value indicates range or replica unavailability, and should be investigated.cockroachdb
rocksdb_block_cache_hitscockroachdb.rocksdb.block.cache.hitsCount of block cache hitscockroachdb
rocksdb_block_cache_missescockroachdb.rocksdb.block.cache.missesCount of block cache missescockroachdb
rocksdb_block_cache_usagecockroachdb.rocksdb.block.cache.usageBytes used by the block cachecockroachdb
rocksdb_bloom_filter_prefix_checkedcockroachdb.rocksdb.bloom.filter.prefix.checkedNumber of times the bloom filter was checkedcockroachdb
rocksdb_bloom_filter_prefix_checkedcockroachdb.rocksdb.bloom_filter.prefix.checkedNumber of times the bloom filter was checkedcockroachdb
rocksdb_bloom_filter_prefix_usefulcockroachdb.rocksdb.bloom.filter.prefix.usefulNumber of times the bloom filter helped avoid iterator creationcockroachdb
rocksdb_bloom_filter_prefix_usefulcockroachdb.rocksdb.bloom_filter.prefix.usefulNumber of times the bloom filter helped avoid iterator creationcockroachdb
rocksdb_compacted_bytes_readcockroachdb.rocksdb.compacted_bytes_readBytes read during compactioncockroachdb
rocksdb_compacted_bytes_writtencockroachdb.rocksdb.compacted_bytes_writtenBytes written during compactioncockroachdb
rocksdb_compactionscockroachdb.rocksdb.compactionsNumber of table compactionscockroachdb
rocksdb_encryption_algorithmcockroachdb.rocksdb.encryption.algorithmAlgorithm in use for encryption-at-rest, see ccl/storageccl/engineccl/enginepbccl/key_registry.protocockroachdb
rocksdb_estimated_pending_compactioncockroachdb.rocksdb.estimated_pending_compactionEstimated pending compaction bytescockroachdb
rocksdb_flushed_bytescockroachdb.rocksdb.flushed_bytesBytes written during flushcockroachdb
rocksdb_flushescockroachdb.rocksdb.flushesNumber of table flushescockroachdb
rocksdb_ingested_bytescockroachdb.rocksdb.ingested_bytesBytes ingestedcockroachdb
rocksdb_memtable_total_sizecockroachdb.rocksdb.memtable.total.sizeCurrent size of memtable in bytescockroachdb
rocksdb_num_sstablescockroachdb.rocksdb.num_sstablesNumber of storage engine SSTablescockroachdb
rocksdb_read_amplificationcockroachdb.rocksdb.read.amplificationNumber of disk reads per querycockroachdb
rocksdb_table_readers_mem_estimatecockroachdb.rocksdb.table.readers.mem.estimateMemory used by index and filter blockscockroachdb
round_trip_latencycockroachdb.round_trip.latency.countDistribution of round-trip latencies with other nodes. This only reflects successful heartbeats and measures gRPC overhead as well as possible head-of-line blocking. Elevated values in this metric may hint at network issues and/or saturation, but they are no proof of them. CPU overload can similarly elevate this metric. The operator should look towards OS-level metrics such as packet loss, retransmits, etc, to conclusively diagnose network issues. Heartbeats are not very frequent (~seconds), so they may not capture rare or short-lived degradations.cockroachdb
round_trip_latencycockroachdb.round_trip_latency.countDistribution of round-trip latencies with other nodes. This only reflects successful heartbeats and measures gRPC overhead as well as possible head-of-line blocking. Elevated values in this metric may hint at network issues and/or saturation, but they are no proof of them. CPU overload can similarly elevate this metric. The operator should look towards OS-level metrics such as packet loss, retransmits, etc, to conclusively diagnose network issues. Heartbeats are not very frequent (~seconds), so they may not capture rare or short-lived degradations.cockroachdb
rpc_batches_recvcockroachdb.rpc.batches.recv.countNumber of batches processedcockroachdb
rpc_connection_avg_round_trip_latencycockroachdb.rpc.connection.avg_round_trip_latencySum of exponentially weighted moving average of round-trip latencies, as measured through a gRPC RPC. Dividing this Gauge by rpc.connection.healthy gives an approximation of average latency, but the top-level round-trip-latency histogram is more useful. Instead, users should consult the label families of this metric if they are available (which requires prometheus and the cluster setting ‘server.child_metrics.enabled’); these provide per-peer moving averages. This metric does not track failed connection. A failed connection’s contribution is reset to zero.cockroachdb
rpc_connection_failurescockroachdb.rpc.connection.failures.countCounter of failed connections. This includes both the event in which a healthy connection terminates as well as unsuccessful reconnection attempts. Connections that are terminated as part of local node shutdown are excluded. Decommissioned peers are excluded.cockroachdb
rpc_connection_healthycockroachdb.rpc.connection.healthyGauge of current connections in a healthy state (i.e. bidirectionally connected and heartbeating)cockroachdb
rpc_connection_healthy_nanoscockroachdb.rpc.connection.healthy_nanosGauge of nanoseconds of healthy connection time On the prometheus endpoint scraped with the cluster setting ‘server.child_metrics.enabled’ set, the constituent parts of this metric are available on a per-peer basis and one can read off for how long a given peer has been connectedcockroachdb
rpc_connection_heartbeatscockroachdb.rpc.connection.heartbeats.countCounter of successful heartbeats.cockroachdb
rpc_connection_inactivecockroachdb.rpc.connection.inactiveGauge of current connections in an inactive state and pending deletion; these are not healthy but are not tracked as unhealthy either because there is reason to believe that the connection is no longer relevant,for example if the node has since been seen under a new addresscockroachdb
rpc_connection_unhealthycockroachdb.rpc.connection.unhealthyGauge of current connections in an unhealthy state (not bidirectionally connected or heartbeating)cockroachdb
rpc_connection_unhealthy_nanoscockroachdb.rpc.connection.unhealthy_nanosGauge of nanoseconds of unhealthy connection time. On the prometheus endpoint scraped with the cluster setting ‘server.child_metrics.enabled’ set, the constituent parts of this metric are available on a per-peer basis and one can read off for how long a given peer has been unreachablecockroachdb
rpc_method_addsstable_recvcockroachdb.rpc.method.addsstable.recv.countNumber of AddSSTable requests processedcockroachdb
rpc_method_adminchangereplicas_recvcockroachdb.rpc.method.adminchangereplicas.recv.countNumber of AdminChangeReplicas requests processedcockroachdb
rpc_method_adminmerge_recvcockroachdb.rpc.method.adminmerge.recv.countNumber of AdminMerge requests processedcockroachdb
rpc_method_adminrelocaterange_recvcockroachdb.rpc.method.adminrelocaterange.recv.countNumber of AdminRelocateRange requests processedcockroachdb
rpc_method_adminscatter_recvcockroachdb.rpc.method.adminscatter.recv.countNumber of AdminScatter requests processedcockroachdb
rpc_method_adminsplit_recvcockroachdb.rpc.method.adminsplit.recv.countNumber of AdminSplit requests processedcockroachdb
rpc_method_admintransferlease_recvcockroachdb.rpc.method.admintransferlease.recv.countNumber of AdminTransferLease requests processedcockroachdb
rpc_method_adminunsplit_recvcockroachdb.rpc.method.adminunsplit.recv.countNumber of AdminUnsplit requests processedcockroachdb
rpc_method_adminverifyprotectedtimestamp_recvcockroachdb.rpc.method.adminverifyprotectedtimestamp.recv.countNumber of AdminVerifyProtectedTimestamp requests processedcockroachdb
rpc_method_barrier_recvcockroachdb.rpc.method.barrier.recv.countNumber of Barrier requests processedcockroachdb
rpc_method_checkconsistency_recvcockroachdb.rpc.method.checkconsistency.recv.countNumber of CheckConsistency requests processedcockroachdb
rpc_method_clearrange_recvcockroachdb.rpc.method.clearrange.recv.countNumber of ClearRange requests processedcockroachdb
rpc_method_computechecksum_recvcockroachdb.rpc.method.computechecksum.recv.countNumber of ComputeChecksum requests processedcockroachdb
rpc_method_conditionalput_recvcockroachdb.rpc.method.conditionalput.recv.countNumber of ConditionalPut requests processedcockroachdb
rpc_method_delete_recvcockroachdb.rpc.method.delete.recv.countNumber of Delete requests processedcockroachdb
rpc_method_deleterange_recvcockroachdb.rpc.method.deleterange.recv.countNumber of DeleteRange requests processedcockroachdb
rpc_method_endtxn_recvcockroachdb.rpc.method.endtxn.recv.countNumber of EndTxn requests processedcockroachdb
rpc_method_export_recvcockroachdb.rpc.method.export.recv.countNumber of Export requests processedcockroachdb
rpc_method_gc_recvcockroachdb.rpc.method.gc.recv.countNumber of GC requests processedcockroachdb
rpc_method_get_recvcockroachdb.rpc.method.get.recv.countNumber of Get requests processedcockroachdb
rpc_method_heartbeattxn_recvcockroachdb.rpc.method.heartbeattxn.recv.countNumber of HeartbeatTxn requests processedcockroachdb
rpc_method_increment_recvcockroachdb.rpc.method.increment.recv.countNumber of Increment requests processedcockroachdb
rpc_method_initput_recvcockroachdb.rpc.method.initput.recv.countNumber of InitPut requests processedcockroachdb
rpc_method_isspanempty_recvcockroachdb.rpc.method.isspanempty.recv.countNumber of IsSpanEmpty requests processedcockroachdb
rpc_method_leaseinfo_recvcockroachdb.rpc.method.leaseinfo.recv.countNumber of LeaseInfo requests processedcockroachdb
rpc_method_merge_recvcockroachdb.rpc.method.merge.recv.countNumber of Merge requests processedcockroachdb
rpc_method_migrate_recvcockroachdb.rpc.method.migrate.recv.countNumber of Migrate requests processedcockroachdb
rpc_method_probe_recvcockroachdb.rpc.method.probe.recv.countNumber of Probe requests processedcockroachdb
rpc_method_pushtxn_recvcockroachdb.rpc.method.pushtxn.recv.countNumber of PushTxn requests processedcockroachdb
rpc_method_put_recvcockroachdb.rpc.method.put.recv.countNumber of Put requests processedcockroachdb
rpc_method_queryintent_recvcockroachdb.rpc.method.queryintent.recv.countNumber of QueryIntent requests processedcockroachdb
rpc_method_querylocks_recvcockroachdb.rpc.method.querylocks.recv.countNumber of QueryLocks requests processedcockroachdb
rpc_method_queryresolvedtimestamp_recvcockroachdb.rpc.method.queryresolvedtimestamp.recv.countNumber of QueryResolvedTimestamp requests processedcockroachdb
rpc_method_querytxn_recvcockroachdb.rpc.method.querytxn.recv.countNumber of QueryTxn requests processedcockroachdb
rpc_method_rangestats_recvcockroachdb.rpc.method.rangestats.recv.countNumber of RangeStats requests processedcockroachdb
rpc_method_recomputestats_recvcockroachdb.rpc.method.recomputestats.recv.countNumber of RecomputeStats requests processedcockroachdb
rpc_method_recovertxn_recvcockroachdb.rpc.method.recovertxn.recv.countNumber of RecoverTxn requests processedcockroachdb
rpc_method_refresh_recvcockroachdb.rpc.method.refresh.recv.countNumber of Refresh requests processedcockroachdb
rpc_method_refreshrange_recvcockroachdb.rpc.method.refreshrange.recv.countNumber of RefreshRange requests processedcockroachdb
rpc_method_requestlease_recvcockroachdb.rpc.method.requestlease.recv.countNumber of RequestLease requests processedcockroachdb
rpc_method_resolveintent_recvcockroachdb.rpc.method.resolveintent.recv.countNumber of ResolveIntent requests processedcockroachdb
rpc_method_resolveintentrange_recvcockroachdb.rpc.method.resolveintentrange.recv.countNumber of ResolveIntentRange requests processedcockroachdb
rpc_method_reversescan_recvcockroachdb.rpc.method.reversescan.recv.countNumber of ReverseScan requests processedcockroachdb
rpc_method_revertrange_recvcockroachdb.rpc.method.revertrange.recv.countNumber of RevertRange requests processedcockroachdb
rpc_method_scan_recvcockroachdb.rpc.method.scan.recv.countNumber of Scan requests processedcockroachdb
rpc_method_subsume_recvcockroachdb.rpc.method.subsume.recv.countNumber of Subsume requests processedcockroachdb
rpc_method_transferlease_recvcockroachdb.rpc.method.transferlease.recv.countNumber of TransferLease requests processedcockroachdb
rpc_method_truncatelog_recvcockroachdb.rpc.method.truncatelog.recv.countNumber of TruncateLog requests processedcockroachdb
rpc_method_writebatch_recvcockroachdb.rpc.method.writebatch.recv.countNumber of WriteBatch requests processedcockroachdb
rpc_streams_mux_rangefeed_activecockroachdb.rpc.streams.mux_rangefeed.activeNumber of currently running MuxRangeFeed streamscockroachdb
rpc_streams_mux_rangefeed_recvcockroachdb.rpc.streams.mux_rangefeed.recv.countTotal number of MuxRangeFeed streamscockroachdb
schedules_BACKUP_failedcockroachdb.schedules.BACKUP.failed.countNumber of BACKUP jobs failedcockroachdb
schedules_BACKUP_failedcockroachdb.schedules.backup.failed.countNumber of BACKUP jobs failedcockroachdb
schedules_BACKUP_last_completed_timecockroachdb.schedules.BACKUP.last_completed_timeThe unix timestamp of the most recently completed backup by a schedule specified as maintaining this metriccockroachdb
schedules_BACKUP_last_completed_timecockroachdb.schedules.backup.last_completed_timeThe unix timestamp of the most recently completed backup by a schedule specified as maintaining this metriccockroachdb
schedules_BACKUP_protected_age_seccockroachdb.schedules.BACKUP.protected_age_secThe age of the oldest PTS record protected by BACKUP schedulescockroachdb
schedules_BACKUP_protected_record_countcockroachdb.schedules.BACKUP.protected_record_countNumber of PTS records held by BACKUP schedulescockroachdb
schedules_BACKUP_startedcockroachdb.schedules.backup.started.countNumber of BACKUP jobs startedcockroachdb
schedules_BACKUP_startedcockroachdb.schedules.BACKUP.started.countNumber of BACKUP jobs startedcockroachdb
schedules_BACKUP_succeededcockroachdb.schedules.BACKUP.succeeded.countNumber of BACKUP jobs succeededcockroachdb
schedules_BACKUP_succeededcockroachdb.schedules.backup.succeeded.countNumber of BACKUP jobs succeededcockroachdb
schedules_CHANGEFEED_failedcockroachdb.schedules.CHANGEFEED.failed.countNumber of CHANGEFEED jobs failedcockroachdb
schedules_CHANGEFEED_startedcockroachdb.schedules.CHANGEFEED.started.countNumber of CHANGEFEED jobs startedcockroachdb
schedules_CHANGEFEED_succeededcockroachdb.schedules.CHANGEFEED.succeeded.countNumber of CHANGEFEED jobs succeededcockroachdb
schedules_errorcockroachdb.schedules.errorNumber of schedules which did not execute successfullycockroachdb
schedules_malformedcockroachdb.schedules.malformedNumber of malformed schedulescockroachdb
schedules_round_jobs_startedcockroachdb.schedules.round.jobs_startedThe number of jobs startedcockroachdb
schedules_round_reschedule_skipcockroachdb.schedules.round.reschedule_skipThe number of schedules rescheduled due to SKIP policycockroachdb
schedules_round_reschedule_waitcockroachdb.schedules.round.reschedule_waitThe number of schedules rescheduled due to WAIT policycockroachdb
schedules_scheduled_row_level_ttl_executor_failedcockroachdb.schedules.scheduled.row.level.ttl.executor_failed.countNumber of scheduled-row-level-ttl-executor jobs failedcockroachdb
schedules_scheduled_row_level_ttl_executor_failedcockroachdb.schedules.scheduled_row_level_ttl_executor.failed.countNumber of scheduled-row-level-ttl-executor jobs failedcockroachdb
schedules_scheduled_row_level_ttl_executor_startedcockroachdb.schedules.scheduled_row_level_ttl_executor.started.countNumber of scheduled-row-level-ttl-executor jobs startedcockroachdb
schedules_scheduled_row_level_ttl_executor_succeededcockroachdb.schedules.scheduled_row_level_ttl_executor.succeeded.countNumber of scheduled-row-level-ttl-executor jobs succeededcockroachdb
schedules_scheduled_schema_telemetry_executor_failedcockroachdb.schedules.scheduled_schema_telemetry_executor.failed.countNumber of scheduled-schema-telemetry-executor jobs failedcockroachdb
schedules_scheduled_schema_telemetry_executor_startedcockroachdb.schedules.scheduled_schema_telemetry_executor.started.countNumber of scheduled-schema-telemetry-executor jobs startedcockroachdb
schedules_scheduled_schema_telemetry_executor_succeededcockroachdb.schedules.scheduled_schema_telemetry_executor.succeeded.countNumber of scheduled-schema-telemetry-executor jobs succeededcockroachdb
schedules_scheduled_sql_stats_compaction_executor_failedcockroachdb.schedules.scheduled_sql_stats_compaction_executor.failed.countNumber of scheduled-sql-stats-compaction-executor jobs failedcockroachdb
schedules_scheduled_sql_stats_compaction_executor_startedcockroachdb.schedules.scheduled_sql_stats_compaction_executor.started.countNumber of scheduled-sql-stats-compaction-executor jobs startedcockroachdb
schedules_scheduled_sql_stats_compaction_executor_succeededcockroachdb.schedules.scheduled_sql_stats_compaction_executor.succeeded.countNumber of scheduled-sql-stats-compaction-executor jobs succeededcockroachdb
spanconfig_kvsubscriber_oldest_protected_record_nanoscockroachdb.spanconfig.kvsubscriber.oldest_protected_record_nanosDifference between the current time and the oldest protected timestamp (sudden drops indicate a record being released; an ever increasing number indicates that the oldest record is around and preventing GC if > configured GC TTL)cockroachdb
spanconfig_kvsubscriber_protected_record_countcockroachdb.spanconfig.kvsubscriber.protected_record_countNumber of protected timestamp records, as seen by KVcockroachdb
spanconfig_kvsubscriber_update_behind_nanoscockroachdb.spanconfig.kvsubscriber.update_behind_nanosDifference between the current time and when the KVSubscriber received its last update (an ever increasing number indicates that we’re no longer receiving updates)cockroachdb
sql_bytesoutcockroachdb.sql.bytesout.countNumber of SQL bytes sentcockroachdb
sql_conn_latencycockroachdb.sql.conn.latency.countLatency to establish and authenticate a SQL connectioncockroachdb
sql_connscockroachdb.sql.connsNumber of open SQL connectionscockroachdb
sql_conns_waiting_to_hashcockroachdb.sql.conns_waiting_to_hashNumber of SQL connection attempts that are being throttled in order to limit password hashing concurrencycockroachdb
sql_contention_resolver_failed_resolutionscockroachdb.sql.contention.resolver.failed_resolutions.countNumber of failed transaction ID resolution attemptscockroachdb
sql_contention_resolver_queue_sizecockroachdb.sql.contention.resolver.queue_sizeLength of queued unresolved contention eventscockroachdb
sql_contention_resolver_retriescockroachdb.sql.contention.resolver.retries.countNumber of times transaction id resolution has been retriedcockroachdb
sql_contention_txn_id_cache_misscockroachdb.sql.contention.txn_id_cache.miss.countNumber of cache missescockroachdb
sql_contention_txn_id_cache_readcockroachdb.sql.contention.txn_id_cache.read.countNumber of cache readcockroachdb
sql_copy_countcockroachdb.sql.copy.countNumber of COPY SQL statements successfully executedcockroachdb
sql_copy_count_internalcockroachdb.sql.copy.internal.countNumber of COPY SQL statements successfully executed (internal queries)cockroachdb
sql_copy_nonatomic_countcockroachdb.sql.copy.nonatomic.countNumber of non-atomic COPY SQL statements successfully executedcockroachdb
sql_copy_nonatomic_count_internalcockroachdb.sql.copy.nonatomic.internal.countNumber of non-atomic COPY SQL statements successfully executed (internal queries)cockroachdb
sql_copy_nonatomic_started_countcockroachdb.sql.copy.nonatomic.started.countNumber of non-atomic COPY SQL statements startedcockroachdb
sql_copy_nonatomic_started_count_internalcockroachdb.sql.copy.nonatomic.started.internal.countNumber of non-atomic COPY SQL statements started (internal queries)cockroachdb
sql_copy_started_countcockroachdb.sql.copy.started.countNumber of COPY SQL statements startedcockroachdb
sql_copy_started_count_internalcockroachdb.sql.copy.started.internal.countNumber of COPY SQL statements started (internal queries)cockroachdb
sql_ddl_countcockroachdb.sql.ddl.countNumber of SQL DDL statements successfully executedcockroachdb
sql_ddl_count_internalcockroachdb.sql.ddl.internal.countNumber of SQL DDL statements successfully executed (internal queries)cockroachdb
sql_ddl_started_countcockroachdb.sql.ddl.started.countNumber of SQL DDL statements startedcockroachdb
sql_ddl_started_count_internalcockroachdb.sql.ddl.started.internal.countNumber of SQL DDL statements started (internal queries)cockroachdb
sql_delete_countcockroachdb.sql.delete.countNumber of SQL DELETE statements successfully executedcockroachdb
sql_delete_count_internalcockroachdb.sql.delete.internal.countNumber of SQL DELETE statements successfully executed (internal queries)cockroachdb
sql_delete_started_countcockroachdb.sql.delete.started.countNumber of SQL DELETE statements startedcockroachdb
sql_delete_started_count_internalcockroachdb.sql.delete.started.internal.countNumber of SQL DELETE statements started (internal queries)cockroachdb
sql_disk_distsql_currentcockroachdb.sql.disk.distsql.currentCurrent sql statement disk usage for distsqlcockroachdb
sql_disk_distsql_maxcockroachdb.sql.disk.distsql.max.countDisk usage per sql statement for distsqlcockroachdb
sql_disk_distsql_spilled_bytes_readcockroachdb.sql.disk.distsql.spilled.bytes.read.countNumber of bytes read from temporary disk storage as a result of spillingcockroachdb
sql_disk_distsql_spilled_bytes_writtencockroachdb.sql.disk.distsql.spilled.bytes.written.countNumber of bytes written to temporary disk storage as a result of spillingcockroachdb
sql_distsql_contended_queries_countcockroachdb.sql.distsql.contended.queries.countNumber of SQL queries that experienced contentioncockroachdb
sql_distsql_dist_query_rerun_locally_countcockroachdb.sql.distsql.dist_query_rerun_locally.countTotal number of cases when distributed query error resulted in a local reruncockroachdb
sql_distsql_exec_latencycockroachdb.sql.distsql.exec.latency.countLatency of DistSQL statement executioncockroachdb
sql_distsql_exec_latency_internalcockroachdb.sql.distsql.exec.latency.internal.countLatency of DistSQL statement execution (internal queries)cockroachdb
sql_distsql_flows_activecockroachdb.sql.distsql.flows.activeNumber of distributed SQL flows currently activecockroachdb
sql_distsql_flows_totalcockroachdb.sql.distsql.flows.total.countNumber of distributed SQL flows executedcockroachdb
sql_distsql_queries_activecockroachdb.sql.distsql.queries.activeNumber of SQL queries currently activecockroachdb
sql_distsql_queries_spilledcockroachdb.sql.distsql.queries.spilled.countNumber of queries that have spilled to diskcockroachdb
sql_distsql_select_countcockroachdb.sql.distsql.select.countNumber of DistSQL SELECT statementscockroachdb
sql_distsql_service_latencycockroachdb.sql.distsql.service.latency.countLatency of DistSQL request executioncockroachdb
sql_distsql_service_latency_internalcockroachdb.sql.distsql.service.latency.internalLatency of DistSQL request execution (internal queries)cockroachdb
sql_distsql_service_latency_internalcockroachdb.sql.distsql.service.latency.internal.countLatency of DistSQL request execution (internal queries)cockroachdb
sql_distsql_vec_openfdscockroachdb.sql.distsql.vec.openfdsCurrent number of open file descriptors used by vectorized external storagecockroachdb
sql_exec_latencycockroachdb.sql.exec.latency.countLatency of SQL statement executioncockroachdb
sql_exec_latency_internalcockroachdb.sql.exec.latency.internal.countLatency of SQL statement execution (internal queries)cockroachdb
sql_exec_latency_internalcockroachdb.sql.exec.latency.internalLatency of SQL statement execution (internal queries)cockroachdb
sql_failure_countcockroachdb.sql.failure.countNumber of statements resulting in a planning or runtime errorcockroachdb
sql_failure_count_internalcockroachdb.sql.failure.internal.countNumber of statements resulting in a planning or runtime error (internal queries)cockroachdb
sql_feature_flag_denialcockroachdb.sql.feature_flag_denial.countCounter of the number of statements denied by a feature flagcockroachdb
sql_full_scan_countcockroachdb.sql.full.scan.countNumber of full table or index scanscockroachdb
sql_full_scan_count_internalcockroachdb.sql.full.scan.internal.countNumber of full table or index scans (internal queries)cockroachdb
sql_guardrails_full_scan_rejected_countcockroachdb.sql.guardrails.full_scan_rejected.countNumber of full table or index scans that have been rejected because of disallow_full_table_scans guardrailcockroachdb
sql_guardrails_full_scan_rejected_count_internalcockroachdb.sql.guardrails.full_scan_rejected.internal.countNumber of full table or index scans that have been rejected because of disallow_full_table_scans guardrail (internal queries)cockroachdb
sql_guardrails_max_row_size_err_countcockroachdb.sql.guardrails.max_row_size_err.countNumber of rows observed violating sql.guardrails.max_row_size_errcockroachdb
sql_guardrails_max_row_size_err_count_internalcockroachdb.sql.guardrails.max_row_size_err.internal.countNumber of rows observed violating sql.guardrails.max_row_size_err (internal queries)cockroachdb
sql_guardrails_max_row_size_log_countcockroachdb.sql.guardrails.max_row_size_log.countNumber of rows observed violating sql.guardrails.max_row_size_logcockroachdb
sql_guardrails_max_row_size_log_count_internalcockroachdb.sql.guardrails.max_row_size_log.internal.countNumber of rows observed violating sql.guardrails.max_row_size_log (internal queries)cockroachdb
sql_guardrails_transaction_rows_read_err_countcockroachdb.sql.guardrails.transaction_rows_read_err.countNumber of transactions errored because of transaction_rows_read_err guardrailcockroachdb
sql_guardrails_transaction_rows_read_err_count_internalcockroachdb.sql.guardrails.transaction_rows_read_err.internal.countNumber of transactions errored because of transaction_rows_read_err guardrail (internal queries)cockroachdb
sql_guardrails_transaction_rows_read_log_countcockroachdb.sql.guardrails.transaction_rows_read_log.countNumber of transactions logged because of transaction_rows_read_log guardrailcockroachdb
sql_guardrails_transaction_rows_read_log_count_internalcockroachdb.sql.guardrails.transaction_rows_read_log.internal.countNumber of transactions logged because of transaction_rows_read_log guardrail (internal queries)cockroachdb
sql_guardrails_transaction_rows_written_err_countcockroachdb.sql.guardrails.transaction_rows_written_err.countNumber of transactions errored because of transaction_rows_written_err guardrailcockroachdb
sql_guardrails_transaction_rows_written_err_count_internalcockroachdb.sql.guardrails.transaction_rows_written_err.internal.countNumber of transactions errored because of transaction_rows_written_err guardrail (internal queries)cockroachdb
sql_guardrails_transaction_rows_written_log_countcockroachdb.sql.guardrails.transaction_rows_written_log.countNumber of transactions logged because of transaction_rows_written_log guardrailcockroachdb
sql_guardrails_transaction_rows_written_log_count_internalcockroachdb.sql.guardrails.transaction_rows_written_log.internal.countNumber of transactions logged because of transaction_rows_written_log guardrail (internal queries)cockroachdb
sql_hydrated_schema_cache_hitscockroachdb.sql.hydrated_schema_cache.hits.countcounter on the number of cache hitscockroachdb
sql_hydrated_schema_cache_missescockroachdb.sql.hydrated_schema_cache.misses.countcounter on the number of cache missescockroachdb
sql_hydrated_table_cache_hitscockroachdb.sql.hydrated_table_cache.hits.countcounter on the number of cache hitscockroachdb
sql_hydrated_table_cache_missescockroachdb.sql.hydrated_table_cache.misses.countcounter on the number of cache missescockroachdb
sql_hydrated_type_cache_hitscockroachdb.sql.hydrated_type_cache.hits.countcounter on the number of cache hitscockroachdb
sql_hydrated_type_cache_missescockroachdb.sql.hydrated_type_cache.misses.countcounter on the number of cache missescockroachdb
sql_hydrated_udf_cache_hitscockroachdb.sql.hydrated_udf_cache.hits.countcounter on the number of cache hitscockroachdb
sql_hydrated_udf_cache_missescockroachdb.sql.hydrated_udf_cache.misses.countcounter on the number of cache missescockroachdb
sql_insert_countcockroachdb.sql.insert.countNumber of SQL INSERT statements successfully executedcockroachdb
sql_insert_count_internalcockroachdb.sql.insert.internal.countNumber of SQL INSERT statements successfully executed (internal queries)cockroachdb
sql_insert_started_countcockroachdb.sql.insert.started.countNumber of SQL INSERT statements startedcockroachdb
sql_insert_started_count_internalcockroachdb.sql.insert.started.internal.countNumber of SQL INSERT statements started (internal queries)cockroachdb
sql_insights_anomaly_detection_evictionscockroachdb.sql.insights.anomaly_detection.evictions.countEvictions of fingerprint latency summaries due to memory pressurecockroachdb
sql_insights_anomaly_detection_fingerprintscockroachdb.sql.insights.anomaly_detection.fingerprintsCurrent number of statement fingerprints being monitored for anomaly detectioncockroachdb
sql_insights_anomaly_detection_memorycockroachdb.sql.insights.anomaly_detection.memoryCurrent memory used to support anomaly detectioncockroachdb
sql_leases_activecockroachdb.sql.leases.activeThe number of outstanding SQL schema leases.cockroachdb
sql_mem_bulk_currentcockroachdb.sql.mem.bulk.currentCurrent sql statement memory usage for bulk operationscockroachdb
sql_mem_bulk_maxcockroachdb.sql.mem.bulk.maxMemory usage per sql statement for bulk operationscockroachdb
sql_mem_bulk_maxcockroachdb.sql.mem.bulk.max.countMemory usage per sql statement for bulk operationscockroachdb
sql_mem_conns_currentcockroachdb.sql.mem.conns.currentCurrent sql statement memory usage for connscockroachdb
sql_mem_conns_maxcockroachdb.sql.mem.conns.max.countMemory usage per sql statement for connscockroachdb
sql_mem_distsql_currentcockroachdb.sql.mem.distsql.currentCurrent sql statement memory usage for distsqlcockroachdb
sql_mem_distsql_maxcockroachdb.sql.mem.distsql.max.countMemory usage per sql statement for distsqlcockroachdb
sql_mem_internal_currentcockroachdb.sql.mem.internal.currentCurrent sql statement memory usage for internalcockroachdb
sql_mem_internal_maxcockroachdb.sql.mem.internal.max.countMemory usage per sql statement for internalcockroachdb
sql_mem_internal_session_currentcockroachdb.sql.mem.internal.session.currentCurrent sql session memory usage for internalcockroachdb
sql_mem_internal_session_maxcockroachdb.sql.mem.internal.session.max.countMemory usage per sql session for internalcockroachdb
sql_mem_internal_session_prepared_currentcockroachdb.sql.mem.internal.session.prepared.currentCurrent sql session memory usage by prepared statements for internalcockroachdb
sql_mem_internal_session_prepared_maxcockroachdb.sql.mem.internal.session.prepared.max.countMemory usage by prepared statements per sql session for internalcockroachdb
sql_mem_internal_txn_currentcockroachdb.sql.mem.internal.txn.currentCurrent sql transaction memory usage for internalcockroachdb
sql_mem_internal_txn_maxcockroachdb.sql.mem.internal.txn.max.countMemory usage per sql transaction for internalcockroachdb
sql_mem_root_currentcockroachdb.sql.mem.root.currentCurrent sql statement memory usage for rootcockroachdb
sql_mem_root_maxcockroachdb.sql.mem.root.max.countMemory usage per sql statement for rootcockroachdb
sql_mem_sql_currentcockroachdb.sql.mem.sql.currentCurrent sql statement memory usage for sqlcockroachdb
sql_mem_sql_maxcockroachdb.sql.mem.sql.maxMemory usage per sql statement for sqlcockroachdb
sql_mem_sql_maxcockroachdb.sql.mem.sql.max.countMemory usage per sql statement for sqlcockroachdb
sql_mem_sql_session_currentcockroachdb.sql.mem.sql.session.currentCurrent sql session memory usage for sqlcockroachdb
sql_mem_sql_session_maxcockroachdb.sql.mem.sql.session.maxMemory usage per sql session for sqlcockroachdb
sql_mem_sql_session_maxcockroachdb.sql.mem.sql.session.max.countMemory usage per sql session for sqlcockroachdb
sql_mem_sql_session_prepared_currentcockroachdb.sql.mem.sql.session.prepared.currentCurrent sql session memory usage by prepared statements for sqlcockroachdb
sql_mem_sql_session_prepared_maxcockroachdb.sql.mem.sql.session.prepared.max.countMemory usage by prepared statements per sql session for sqlcockroachdb
sql_mem_sql_session_prepared_maxcockroachdb.sql.mem.sql.session.prepared.maxMemory usage by prepared statements per sql session for sqlcockroachdb
sql_mem_sql_txn_currentcockroachdb.sql.mem.sql.txn.currentCurrent sql transaction memory usage for sqlcockroachdb
sql_mem_sql_txn_maxcockroachdb.sql.mem.sql.txn.maxMemory usage per sql transaction for sqlcockroachdb
sql_mem_sql_txn_maxcockroachdb.sql.mem.sql.txn.max.countMemory usage per sql transaction for sqlcockroachdb
sql_misc_countcockroachdb.sql.misc.countNumber of other SQL statements successfully executedcockroachdb
sql_misc_count_internalcockroachdb.sql.misc.internal.countNumber of other SQL statements successfully executed (internal queries)cockroachdb
sql_misc_started_countcockroachdb.sql.misc.started.countNumber of other SQL statements startedcockroachdb
sql_misc_started_count_internalcockroachdb.sql.misc.started.internal.countNumber of other SQL statements started (internal queries)cockroachdb
sql_new_connscockroachdb.sql.new_conns.countNumber of SQL connections createdcockroachdb
sql_optimizer_fallback_countcockroachdb.sql.optimizer.fallback.countNumber of statements which the cost-based optimizer was unable to plancockroachdb
sql_optimizer_fallback_count_internalcockroachdb.sql.optimizer.fallback.internal.countNumber of statements which the cost-based optimizer was unable to plan (internal queries)cockroachdb
sql_optimizer_plan_cache_hitscockroachdb.sql.optimizer.plan_cache.hits.countNumber of non-prepared statements for which a cached plan was usedcockroachdb
sql_optimizer_plan_cache_hits_internalcockroachdb.sql.optimizer.plan_cache.hits.internal.countNumber of non-prepared statements for which a cached plan was used (internal queries)cockroachdb
sql_optimizer_plan_cache_missescockroachdb.sql.optimizer.plan_cache.misses.countNumber of non-prepared statements for which a cached plan was not usedcockroachdb
sql_optimizer_plan_cache_misses_internalcockroachdb.sql.optimizer.plan_cache.misses.internal.countNumber of non-prepared statements for which a cached plan was not used (internal queries)cockroachdb
sql_pgwire_cancel_ignoredcockroachdb.sql.pgwire_cancel.ignored.countNumber of pgwire query cancel requests that were ignored due to rate limitingcockroachdb
sql_pgwire_cancel_successfulcockroachdb.sql.pgwire_cancel.successful.countNumber of pgwire query cancel requests that were successfulcockroachdb
sql_pre_serve_bytesincockroachdb.sql.pre_serve.bytesin.countNumber of SQL bytes received prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_bytesoutcockroachdb.sql.pre_serve.bytesout.countNumber of SQL bytes sent prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_conn_failurescockroachdb.sql.pre_serve.conn.failures.countNumber of SQL connection failures prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_mem_curcockroachdb.sql.pre_serve.mem.curCurrent memory usage for SQL connections prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_mem_maxcockroachdb.sql.pre_serve.mem.maxMemory usage for SQL connections prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_mem_maxcockroachdb.sql.pre_serve.mem.max.countMemory usage for SQL connections prior to routing the connection to the target SQL servercockroachdb
sql_pre_serve_new_connscockroachdb.sql.pre_serve.new_conns.countNumber of SQL connections created prior to routing the connection to the target SQL servercockroachdb
sql_query_countcockroachdb.sql.query.countNumber of SQL operations started including queries, and transaction control statementscockroachdb
sql_query_count_internalcockroachdb.sql.query.internal.countNumber of SQL operations started including queries, and transaction control statements (internal queries)cockroachdb
sql_query_started_countcockroachdb.sql.query.started.countNumber of SQL operations started including queries, and transaction control statementscockroachdb
sql_query_started_count_internalcockroachdb.sql.query.started.internal.countNumber of SQL operations started including queries, and transaction control statements (internal queries)cockroachdb
sql_restart_savepoint_countcockroachdb.sql.restart_savepoint.countNumber of SAVEPOINT cockroach_restart statements successfully executedcockroachdb
sql_restart_savepoint_count_internalcockroachdb.sql.restart_savepoint.internal.countNumber of SAVEPOINT cockroach_restart statements successfully executed (internal queries)cockroachdb
sql_restart_savepoint_release_countcockroachdb.sql.restart_savepoint.release.countNumber of RELEASE SAVEPOINT cockroach_restart statements successfully executedcockroachdb
sql_restart_savepoint_release_count_internalcockroachdb.sql.restart_savepoint.release.internal.countNumber of RELEASE SAVEPOINT cockroach_restart statements successfully executed (internal queries)cockroachdb
sql_restart_savepoint_release_started_countcockroachdb.sql.restart_savepoint.release.started.countNumber of RELEASE SAVEPOINT cockroach_restart statements startedcockroachdb
sql_restart_savepoint_release_started_count_internalcockroachdb.sql.restart_savepoint.release.started.internal.countNumber of RELEASE SAVEPOINT cockroach_restart statements started (internal queries)cockroachdb
sql_restart_savepoint_rollback_countcockroachdb.sql.restart_savepoint.rollback.countNumber of ROLLBACK TO SAVEPOINT cockroach_restart statements successfully executedcockroachdb
sql_restart_savepoint_rollback_count_internalcockroachdb.sql.restart_savepoint.rollback.internal.countNumber of ROLLBACK TO SAVEPOINT cockroach_restart statements successfully executed (internal queries)cockroachdb
sql_restart_savepoint_rollback_started_countcockroachdb.sql.restart_savepoint.rollback.started.countNumber of ROLLBACK TO SAVEPOINT cockroach_restart statements startedcockroachdb
sql_restart_savepoint_rollback_started_count_internalcockroachdb.sql.restart_savepoint.rollback.started.internal.countNumber of ROLLBACK TO SAVEPOINT cockroach_restart statements started (internal queries)cockroachdb
sql_restart_savepoint_started_countcockroachdb.sql.restart_savepoint.started.countNumber of SAVEPOINT cockroach_restart statements startedcockroachdb
sql_restart_savepoint_started_count_internalcockroachdb.sql.restart_savepoint.started.internal.countNumber of SAVEPOINT cockroach_restart statements started (internal queries)cockroachdb
sql_savepoint_countcockroachdb.sql.savepoint.countNumber of SQL SAVEPOINT statements successfully executedcockroachdb
sql_savepoint_count_internalcockroachdb.sql.savepoint.internal.countNumber of SQL SAVEPOINT statements successfully executed (internal queries)cockroachdb
sql_savepoint_release_countcockroachdb.sql.savepoint.release.countNumber of RELEASE SAVEPOINT statements successfully executedcockroachdb
sql_savepoint_release_count_internalcockroachdb.sql.savepoint.release.internal.countNumber of RELEASE SAVEPOINT statements successfully executed (internal queries)cockroachdb
sql_savepoint_release_started_countcockroachdb.sql.savepoint.release.started.countNumber of RELEASE SAVEPOINT statements startedcockroachdb
sql_savepoint_release_started_count_internalcockroachdb.sql.savepoint.release.started.internal.countNumber of RELEASE SAVEPOINT statements started (internal queries)cockroachdb
sql_savepoint_rollback_countcockroachdb.sql.savepoint.rollback.countNumber of ROLLBACK TO SAVEPOINT statements successfully executedcockroachdb
sql_savepoint_rollback_count_internalcockroachdb.sql.savepoint.rollback.internal.countNumber of ROLLBACK TO SAVEPOINT statements successfully executed (internal queries)cockroachdb
sql_savepoint_rollback_started_countcockroachdb.sql.savepoint.rollback.started.countNumber of ROLLBACK TO SAVEPOINT statements startedcockroachdb
sql_savepoint_rollback_started_count_internalcockroachdb.sql.savepoint.rollback.started.internal.countNumber of ROLLBACK TO SAVEPOINT statements started (internal queries)cockroachdb
sql_savepoint_started_countcockroachdb.sql.savepoint.started.countNumber of SQL SAVEPOINT statements startedcockroachdb
sql_savepoint_started_count_internalcockroachdb.sql.savepoint.started.internal.countNumber of SQL SAVEPOINT statements started (internal queries)cockroachdb
sql_schema_changer_permanent_errorscockroachdb.sql.schema_changer.permanent_errors.countCounter of the number of permanent errors experienced by the schema changercockroachdb
sql_schema_changer_retry_errorscockroachdb.sql.schema_changer.retry_errors.countCounter of the number of retriable errors experienced by the schema changercockroachdb
sql_schema_changer_runningcockroachdb.sql.schema_changer.runningGauge of currently running schema changescockroachdb
sql_schema_changer_successescockroachdb.sql.schema_changer.successes.countCounter of the number of schema changer resumes which succeedcockroachdb
sql_schema_invalid_objectscockroachdb.sql.schema.invalid_objectsGauge of detected invalid objects within the system.descriptor table (measured by querying crdb_internal.invalid_objects)cockroachdb
sql_select_countcockroachdb.sql.select.countNumber of SQL SELECT statements successfully executedcockroachdb
sql_select_count_internalcockroachdb.sql.select.internal.countNumber of SQL SELECT statements successfully executed (internal queries)cockroachdb
sql_select_started_countcockroachdb.sql.select.started.countNumber of SQL SELECT statements startedcockroachdb
sql_select_started_count_internalcockroachdb.sql.select.started.internal.countNumber of SQL SELECT statements started (internal queries)cockroachdb
sql_service_latencycockroachdb.sql.service.latency.countLatency of SQL request executioncockroachdb
sql_service_latency_internalcockroachdb.sql.service.latency.internalLatency of SQL request execution (internal queries)cockroachdb
sql_service_latency_internalcockroachdb.sql.service.latency.internal.countLatency of SQL request execution (internal queries)cockroachdb
sql_statements_activecockroachdb.sql.statements.activeNumber of currently active user SQL statementscockroachdb
sql_statements_active_internalcockroachdb.sql.statements.active.internalNumber of currently active user SQL statements (internal queries)cockroachdb
sql_stats_cleanup_rows_removedcockroachdb.sql.stats.cleanup.rows_removed.countNumber of stale statistics rows that are removedcockroachdb
sql_stats_discarded_currentcockroachdb.sql.stats.discarded.current.countNumber of fingerprint statistics being discardedcockroachdb
sql_stats_mem_currentcockroachdb.sql.stats.mem.currentCurrent memory usage for fingerprint storagecockroachdb
sql_stats_mem_maxcockroachdb.sql.stats.mem.maxMemory usage for fingerprint storagecockroachdb
sql_stats_mem_maxcockroachdb.sql.stats.mem.max.countMemory usage for fingerprint storagecockroachdb
sql_stats_reported_mem_currentcockroachdb.sql.stats.reported.mem.currentCurrent memory usage for reported fingerprint storagecockroachdb
sql_stats_reported_mem_maxcockroachdb.sql.stats.reported.mem.max.countMemory usage for reported fingerprint storagecockroachdb
sql_stats_reported_mem_maxcockroachdb.sql.stats.reported.mem.maxMemory usage for reported fingerprint storagecockroachdb
sql_stats_txn_stats_collection_durationcockroachdb.sql.stats.txn_stats_collection.durationTime took in nanoseconds to collect transaction statscockroachdb
sql_stats_txn_stats_collection_durationcockroachdb.sql.stats.txn_stats_collection.duration.countTime took in nanoseconds to collect transaction statscockroachdb
sql_temp_object_cleaner_active_cleanerscockroachdb.sql.temp_object_cleaner.active_cleanersnumber of cleaner tasks currently running on this nodecockroachdb
sql_temp_object_cleaner_schemas_deletion_errorcockroachdb.sql.temp_object_cleaner.schemas_deletion_error.countnumber of errored schema deletions by the temp object cleaner on this nodecockroachdb
sql_temp_object_cleaner_schemas_deletion_successcockroachdb.sql.temp_object_cleaner.schemas_deletion_success.countnumber of successful schema deletions by the temp object cleaner on this nodecockroachdb
sql_temp_object_cleaner_schemas_to_deletecockroachdb.sql.temp_object_cleaner.schemas_to_delete.countnumber of schemas to be deleted by the temp object cleaner on this nodecockroachdb
sql_txn_abort_countcockroachdb.sql.txn.abort.countNumber of SQL transaction abort errorscockroachdb
sql_txn_abort_count_internalcockroachdb.sql.txn.abort.internal.countNumber of SQL transaction abort errors (internal queries)cockroachdb
sql_txn_begin_countcockroachdb.sql.txn.begin.countNumber of SQL transaction BEGIN statements successfully executedcockroachdb
sql_txn_begin_count_internalcockroachdb.sql.txn.begin.internal.countNumber of SQL transaction BEGIN statements successfully executed (internal queries)cockroachdb
sql_txn_begin_started_countcockroachdb.sql.txn.begin.started.countNumber of SQL transaction BEGIN statements startedcockroachdb
sql_txn_begin_started_count_internalcockroachdb.sql.txn.begin.started.internal.countNumber of SQL transaction BEGIN statements started (internal queries)cockroachdb
sql_txn_commit_countcockroachdb.sql.txn.commit.countNumber of SQL transaction COMMIT statements successfully executedcockroachdb
sql_txn_commit_count_internalcockroachdb.sql.txn.commit.internal.countNumber of SQL transaction COMMIT statements successfully executed (internal queries)cockroachdb
sql_txn_commit_started_countcockroachdb.sql.txn.commit.started.countNumber of SQL transaction COMMIT statements startedcockroachdb
sql_txn_commit_started_count_internalcockroachdb.sql.txn.commit.started.internal.countNumber of SQL transaction COMMIT statements started (internal queries)cockroachdb
sql_txn_contended_countcockroachdb.sql.txn.contended.countNumber of SQL transactions experienced contentioncockroachdb
sql_txn_contended_count_internalcockroachdb.sql.txn.contended.internal.countNumber of SQL transactions experienced contention (internal queries)cockroachdb
sql_txn_latencycockroachdb.sql.txn.latency.countLatency of SQL transactionscockroachdb
sql_txn_latency_internalcockroachdb.sql.txn.latency.internal.countLatency of SQL transactions (internal queries)cockroachdb
sql_txn_rollback_countcockroachdb.sql.txn.rollback.countNumber of SQL transaction ROLLBACK statements successfully executedcockroachdb
sql_txn_rollback_count_internalcockroachdb.sql.txn.rollback.internal.countNumber of SQL transaction ROLLBACK statements successfully executed (internal queries)cockroachdb
sql_txn_rollback_started_countcockroachdb.sql.txn.rollback.started.countNumber of SQL transaction ROLLBACK statements startedcockroachdb
sql_txn_rollback_started_count_internalcockroachdb.sql.txn.rollback.started.internal.countNumber of SQL transaction ROLLBACK statements started (internal queries)cockroachdb
sql_txns_opencockroachdb.sql.txns.openNumber of currently open user SQL transactionscockroachdb
sql_txns_open_internalcockroachdb.sql.txns.open.internalNumber of currently open user SQL transactions (internal queries)cockroachdb
sql_update_countcockroachdb.sql.update.countNumber of SQL UPDATE statements successfully executedcockroachdb
sql_update_count_internalcockroachdb.sql.update.internal.countNumber of SQL UPDATE statements successfully executed (internal queries)cockroachdb
sql_update_started_countcockroachdb.sql.update.started.countNumber of SQL UPDATE statements startedcockroachdb
sql_update_started_count_internalcockroachdb.sql.update.started.internal.countNumber of SQL UPDATE statements started (internal queries)cockroachdb
sqlliveness_is_alive_cache_hitscockroachdb.sqlliveness.is_alive.cache_hits.countNumber of calls to IsAlive that return from the cachecockroachdb
sqlliveness_is_alive_cache_missescockroachdb.sqlliveness.is_alive.cache_misses.countNumber of calls to IsAlive that do not return from the cachecockroachdb
sqlliveness_sessions_deletedcockroachdb.sqlliveness.sessions_deleted.countNumber of expired sessions which have been deletedcockroachdb
sqlliveness_sessions_deletion_runscockroachdb.sqlliveness.sessions_deletion_runs.countNumber of calls to delete sessions which have been performedcockroachdb
sqlliveness_write_failurescockroachdb.sqlliveness.write_failures.countNumber of update or insert calls which have failedcockroachdb
sqlliveness_write_successescockroachdb.sqlliveness.write_successes.countNumber of update or insert calls successfully performedcockroachdb
storage_batch_commit_commit_wait_durationcockroachdb.storage.batch_commit.commit_wait.durationCumulative time spent waiting for WAL sync, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_countcockroachdb.storage.batch_commitCount of batch commits. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_durationcockroachdb.storage.batch_commit.durationCumulative time spent in batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_l0_stall_durationcockroachdb.storage.batch_commit.l0_stall.durationCumulative time spent in a write stall due to high read amplification in L0, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_mem_stall_durationcockroachdb.storage.batch_commit.mem_stall.durationCumulative time spent in a write stall due to too many memtables, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_sem_wait_durationcockroachdb.storage.batch_commit.sem_wait.durationCumulative time spent in semaphore wait, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_wal_queue_wait_durationcockroachdb.storage.batch_commit.wal_queue_wait.durationCumulative time spent waiting for memory blocks in the WAL queue, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_batch_commit_wal_rotation_durationcockroachdb.storage.batch_commit.wal_rotation.durationCumulative time spent waiting for WAL rotation, for batch commit. See storage.AggregatedBatchCommitStats for details.cockroachdb
storage_checkpointscockroachdb.storage.checkpointsThe number of checkpoint directories found in storage. This is the number of directories found in the auxiliary/checkpoints directory. Each represents an immutable point-in-time storage engine checkpoint. They are cheap (consisting mostly of hard links), but over time they effectively become a full copy of the old state, which increases their relative cost. Checkpoints must be deleted once acted upon (e.g. copied elsewhere or investigated). A likely cause of having a checkpoint is that one of the ranges in this store had inconsistent data among its replicas. Such checkpoint directories are located in auxiliary/checkpoints/rN_at_M, where N is the range ID, and M is the Raft applied index at which this checkpoint was taken.cockroachdb
storage_compactions_durationcockroachdb.storage.compactions.durationCumulative sum of all compaction durations. The rate of this value provides the effective compaction concurrency of a store, which can be useful to determine whether the maximum compaction concurrency is fully utilized.cockroachdb
storage_compactions_keys_pinned_bytescockroachdb.storage.compactions.keys.pinned.bytesCumulative size of storage engine KVs written to sstables during flushes and compactions due to open LSM snapshots. Various subsystems of CockroachDB take LSM snapshots to maintain a consistent view of the database over an extended duration. In order to maintain the consistent view, flushes and compactions within the storage engine must preserve keys that otherwise would have been dropped. This increases write amplification, and introduces keys that must be skipped during iteration. This metric records the cumulative number of bytes preserved during flushes and compactions over the lifetime of the process.cockroachdb
storage_compactions_keys_pinned_countcockroachdb.storage.compactions.keys.pinnedCumulative count of storage engine KVs written to sstables during flushes and compactions due to open LSM snapshots. Various subsystems of CockroachDB take LSM snapshots to maintain a consistent view of the database over an extended duration. In order to maintain the consistent view, flushes and compactions within the storage engine must preserve keys that otherwise would have been dropped. This increases write amplification, and introduces keys that must be skipped during iteration. This metric records the cumulative count of KVs preserved during flushes and compactions over the lifetime of the process.cockroachdb
storage_disk_slowcockroachdb.storage.disk_slowNumber of instances of disk operations taking longer than 10scockroachdb
storage_disk_stalledcockroachdb.storage.disk_stalledNumber of instances of disk operations taking longer than 20scockroachdb
storage_flush_ingest_countcockroachdb.storage.flush.ingestFlushes performing an ingest (flushable ingestions)cockroachdb
storage_flush_ingest_table_bytescockroachdb.storage.flush.ingest.table.bytesBytes ingested via flushes (flushable ingestions)cockroachdb
storage_flush_ingest_table_countcockroachdb.storage.flush.ingest.tableTables ingested via flushes (flushable ingestions)cockroachdb
storage_flush_utilizationcockroachdb.storage.flush.utilizationThe percentage of time the storage engine is actively flushing memtables to disk.cockroachdb
storage_ingest_countcockroachdb.storage.ingestNumber of successful ingestions performedcockroachdb
storage_iterator_block_load_bytescockroachdb.storage.iterator.block_load.bytesBytes loaded by storage engine iterators (possibly cached). See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_block_load_cached_bytescockroachdb.storage.iterator.block_load.cached_bytesBytes loaded by storage engine iterators from the block cache. See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_block_load_read_durationcockroachdb.storage.iterator.block_load.read_durationCumulative time storage engine iterators spent loading blocks from durable storage. See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_external_seekscockroachdb.storage.iterator.external.seeksCumulative count of seeks performed on storage engine iterators. See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_external_stepscockroachdb.storage.iterator.external.stepsCumulative count of steps performed on storage engine iterators. See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_internal_seekscockroachdb.storage.iterator.internal.seeksCumulative count of seeks performed internally within storage engine iterators. A value high relative to ‘storage.iterator.external.seeks’ is a good indication that there’s an accumulation of garbage internally within the storage engine. See storage.AggregatedIteratorStats for details.cockroachdb
storage_iterator_internal_stepscockroachdb.storage.iterator.internal.stepsCumulative count of steps performed internally within storage engine iterators. A value high relative to ‘storage.iterator.external.steps’ is a good indication that there’s an accumulation of garbage internally within the storage engine. See storage.AggregatedIteratorStats for more details.cockroachdb
storage_keys_range_key_set_countcockroachdb.storage.keys.range_key_setApproximate count of RangeKeySet internal keys across the storage engine.cockroachdb
storage_keys_tombstone_countcockroachdb.storage.keys.tombstoneApproximate count of DEL, SINGLEDEL and RANGEDEL internal keys across the storage engine.cockroachdb
storage_l0_bytes_flushedcockroachdb.storage.l0_bytes_flushedNumber of bytes flushed (from memtables) into Level 0cockroachdb
storage_l0_bytes_ingestedcockroachdb.storage.l0_bytes_ingestedNumber of bytes ingested directly into Level 0cockroachdb
storage_l0_level_scorecockroachdb.storage.l0_level_scoreCompaction score of level 0cockroachdb
storage_l0_level_sizecockroachdb.storage.l0_level_sizeSize of the SSTables in level 0cockroachdb
storage_l0_num_filescockroachdb.storage.l0_num_filesNumber of SSTables in Level 0cockroachdb
storage_l0_sublevelscockroachdb.storage.l0_sublevelsNumber of Level 0 sublevelscockroachdb
storage_l1_bytes_ingestedcockroachdb.storage.l1_bytes_ingestedNumber of bytes ingested directly into Level 1cockroachdb
storage_l1_level_scorecockroachdb.storage.l1_level_scoreCompaction score of level 1cockroachdb
storage_l1_level_sizecockroachdb.storage.l1_level_sizeSize of the SSTables in level 1cockroachdb
storage_l2_bytes_ingestedcockroachdb.storage.l2_bytes_ingestedNumber of bytes ingested directly into Level 2cockroachdb
storage_l2_level_scorecockroachdb.storage.l2_level_scoreCompaction score of level 2cockroachdb
storage_l2_level_sizecockroachdb.storage.l2_level_sizeSize of the SSTables in level 2cockroachdb
storage_l3_bytes_ingestedcockroachdb.storage.l3_bytes_ingestedNumber of bytes ingested directly into Level 3cockroachdb
storage_l3_level_scorecockroachdb.storage.l3_level_scoreCompaction score of level 3cockroachdb
storage_l3_level_sizecockroachdb.storage.l3_level_sizeSize of the SSTables in level 3cockroachdb
storage_l4_bytes_ingestedcockroachdb.storage.l4_bytes_ingestedNumber of bytes ingested directly into Level 4cockroachdb
storage_l4_level_scorecockroachdb.storage.l4_level_scoreCompaction score of level 4cockroachdb
storage_l4_level_sizecockroachdb.storage.l4_level_sizeSize of the SSTables in level 4cockroachdb
storage_l5_bytes_ingestedcockroachdb.storage.l5_bytes_ingestedNumber of bytes ingested directly into Level 5cockroachdb
storage_l5_level_scorecockroachdb.storage.l5_level_scoreCompaction score of level 5cockroachdb
storage_l5_level_sizecockroachdb.storage.l5_level_sizeSize of the SSTables in level 5cockroachdb
storage_l6_bytes_ingestedcockroachdb.storage.l6_bytes_ingestedNumber of bytes ingested directly into Level 6cockroachdb
storage_l6_level_scorecockroachdb.storage.l6_level_scoreCompaction score of level 6cockroachdb
storage_l6_level_sizecockroachdb.storage.l6_level_sizeSize of the SSTables in level 6cockroachdb
storage_marked_for_compaction_filescockroachdb.storage.marked_for_compaction_filesCount of SSTables marked for compactioncockroachdb
storage_queue_store_failurescockroachdb.storage.queue.store_failures.countNumber of replicas which failed processing in replica queues due to retryable store errorscockroachdb
storage_secondary_cache_countcockroachdb.storage.secondary_cacheThe count of cache blocks in the secondary cache (not sstable blocks)cockroachdb
storage_secondary_cache_evictionscockroachdb.storage.secondary_cache.evictionsThe number of times a cache block was evicted from the secondary cachecockroachdb
storage_secondary_cache_reads_full_hitcockroachdb.storage.secondary_cache.reads_full_hitThe number of reads where all data returned was read from the secondary cachecockroachdb
storage_secondary_cache_reads_multi_blockcockroachdb.storage.secondary_cache.reads_multi_blockThe number of secondary cache reads that require reading data from 2+ cache blockscockroachdb
storage_secondary_cache_reads_multi_shardcockroachdb.storage.secondary_cache.reads_multi_shardThe number of secondary cache reads that require reading data from 2+ shardscockroachdb
storage_secondary_cache_reads_no_hitcockroachdb.storage.secondary_cache.reads_no_hitThe number of reads where no data returned was read from the secondary cachecockroachdb
storage_secondary_cache_reads_partial_hitcockroachdb.storage.secondary_cache.reads_partial_hitThe number of reads where some data returned was read from the secondary cachecockroachdb
storage_secondary_cache_reads_totalcockroachdb.storage.secondary_cache.reads_totalThe number of reads from the secondary cachecockroachdb
storage_secondary_cache_sizecockroachdb.storage.secondary_cache.sizeThe number of sstable bytes stored in the secondary cachecockroachdb
storage_secondary_cache_write_back_failurescockroachdb.storage.secondary_cache.write_back_failuresThe number of times writing a cache block to the secondary cache failedcockroachdb
storage_shared_storage_readcockroachdb.storage.shared_storage.readBytes read from shared storagecockroachdb
storage_shared_storage_writecockroachdb.storage.shared_storage.writeBytes written to external storagecockroachdb
storage_single_delete_ineffectualcockroachdb.storage.single_delete.ineffectualNumber of SingleDeletes that were ineffectualcockroachdb
storage_single_delete_invariant_violationcockroachdb.storage.single_delete.invariant_violationNumber of SingleDelete invariant violationscockroachdb
storage_wal_bytes_incockroachdb.storage.wal.bytes_inThe number of logical bytes the storage engine has written to the WALcockroachdb
storage_wal_bytes_writtencockroachdb.storage.wal.bytes_writtenThe number of bytes the storage engine has written to the WALcockroachdb
storage_wal_fsync_latencycockroachdb.storage.wal.fsync.latency.countThe write ahead log fsync latencycockroachdb
storage_write_stall_nanoscockroachdb.storage.write_stall_nanosTotal write stall duration in nanoscockroachdb
storage_write_stallscockroachdb.storage.write_stallsNumber of instances of intentional write stalls to backpressure incoming writescockroachdb
storage_write_stallscockroachdb.storage.write.stallsNumber of instances of intentional write stalls to backpressure incoming writescockroachdb
sys_cgo_allocbytescockroachdb.sys.cgo.allocbytesCurrent bytes of memory allocated by cgocockroachdb
sys_cgo_totalbytescockroachdb.sys.cgo.totalbytesTotal bytes of memory allocated by cgo, but not releasedcockroachdb
sys_cgocallscockroachdb.sys.cgocallsTotal number of cgo callscockroachdb
sys_cpu_combined_percent_normalizedcockroachdb.sys.cpu.combined.percent.normalizedCurrent user+system cpu percentage consumed by the CRDB process, normalized 0-1 by number of corescockroachdb
sys_cpu_host_combined_percent_normalizedcockroachdb.sys.cpu.host.combined.percent_normalizedCurrent user+system cpu percentage across the whole machine, normalized 0-1 by number of corescockroachdb
sys_cpu_now_nscockroachdb.sys.cpu.now.nsThe time when CPU measurements were taken, as nanoseconds since epochcockroachdb
sys_cpu_sys_nscockroachdb.sys.cpu.sys.nsTotal system cpu time consumed by the CRDB processcockroachdb
sys_cpu_sys_percentcockroachdb.sys.cpu.sys.percentCurrent system cpu percentage consumed by the CRDB processcockroachdb
sys_cpu_user_nscockroachdb.sys.cpu.user.nsTotal user cpu time consumed by the CRDB processcockroachdb
sys_cpu_user_percentcockroachdb.sys.cpu.user.percentCurrent user cpu percentage consumed by the CRDB processcockroachdb
sys_fd_opencockroachdb.sys.fd.openProcess open file descriptorscockroachdb
sys_fd_softlimitcockroachdb.sys.fd.softlimitProcess open FD soft limitcockroachdb
sys_gc_countcockroachdb.sys.gcTotal number of GC runscockroachdb
sys_gc_pause_nscockroachdb.sys.gc.pause.nsTotal GC pausecockroachdb
sys_gc_pause_percentcockroachdb.sys.gc.pause.percentCurrent GC pause percentagecockroachdb
sys_go_allocbytescockroachdb.sys.go.allocbytesCurrent bytes of memory allocated by gocockroachdb
sys_go_totalbytescockroachdb.sys.go.totalbytesTotal bytes of memory allocated by go, but not releasedcockroachdb
sys_goroutinescockroachdb.sys.goroutinesCurrent number of goroutinescockroachdb
sys_host_disk_io_timecockroachdb.sys.host.disk.io.timeTime spent reading from or writing to all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_iopsinprogresscockroachdb.sys.host.disk.iopsinprogressIO operations currently in progress on this host (as reported by the OS)cockroachdb
sys_host_disk_read_bytescockroachdb.sys.host.disk.read.bytesBytes read from all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_read_countcockroachdb.sys.host.disk.readDisk read operations across all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_read_timecockroachdb.sys.host.disk.read.timeTime spent reading from all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_weightedio_timecockroachdb.sys.host.disk.weightedio.timeWeighted time spent reading from or writing to all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_write_bytescockroachdb.sys.host.disk.write.bytesBytes written to all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_write_countcockroachdb.sys.host.disk.writeDisk write operations across all disks since this process started (as reported by the OS)cockroachdb
sys_host_disk_write_timecockroachdb.sys.host.disk.write.timeTime spent writing to all disks since this process started (as reported by the OS)cockroachdb
sys_host_net_recv_bytescockroachdb.sys.host.net.recv.bytesBytes received on all network interfaces since this process started (as reported by the OS)cockroachdb
sys_host_net_recv_packetscockroachdb.sys.host.net.recv.packetsPackets received on all network interfaces since this process started (as reported by the OS)cockroachdb
sys_host_net_send_bytescockroachdb.sys.host.net.send.bytesBytes sent on all network interfaces since this process started (as reported by the OS)cockroachdb
sys_host_net_send_packetscockroachdb.sys.host.net.send.packetsPackets sent on all network interfaces since this process started (as reported by the OS)cockroachdb
sys_rsscockroachdb.sys.rssCurrent process RSScockroachdb
sys_runnable_goroutines_per_cpucockroachdb.sys.runnable.goroutines.per.cpuAverage number of goroutines that are waiting to run, normalized by number of corescockroachdb
sys_runnable_goroutines_per_cpucockroachdb.sys.runnable.goroutines.per_cpuAverage number of goroutines that are waiting to run, normalized by number of corescockroachdb
sys_totalmemcockroachdb.sys.totalmemTotal memory (both free and used)cockroachdb
sys_uptimecockroachdb.sys.uptimeProcess uptimecockroachdb
sysbytescockroachdb.sysbytesNumber of bytes in system KV pairscockroachdb
syscountcockroachdb.syscountCount of system KV pairscockroachdb
tenant_consumption_cross_region_network_rucockroachdb.tenant.consumption.cross_region_network_ru.countTotal number of RUs charged for cross-region network trafficcockroachdb
tenant_consumption_external_io_egress_bytescockroachdb.tenant.consumption.external_io_egress_bytesTotal number of bytes written to external services such as cloud storage providerscockroachdb
tenant_consumption_external_io_ingress_bytescockroachdb.tenant.consumption.external_io_ingress_bytesTotal number of bytes read from external services such as cloud storage providerscockroachdb
tenant_consumption_kv_request_unitscockroachdb.tenant.consumption.kv_request_unitsRU consumption attributable to KVcockroachdb
tenant_consumption_kv_request_unitscockroachdb.tenant.consumption.kv_request_units.countRU consumption attributable to KVcockroachdb
tenant_consumption_pgwire_egress_bytescockroachdb.tenant.consumption.pgwire_egress_bytesTotal number of bytes transferred from a SQL pod to the clientcockroachdb
tenant_consumption_read_batchescockroachdb.tenant.consumption.read_batchesTotal number of KV read batchescockroachdb
tenant_consumption_read_bytescockroachdb.tenant.consumption.read_bytesTotal number of bytes read from KVcockroachdb
tenant_consumption_read_requestscockroachdb.tenant.consumption.read_requestsTotal number of KV read requestscockroachdb
tenant_consumption_request_unitscockroachdb.tenant.consumption.request_units.countTotal RU consumptioncockroachdb
tenant_consumption_request_unitscockroachdb.tenant.consumption.request_unitsTotal RU consumptioncockroachdb
tenant_consumption_sql_pods_cpu_secondscockroachdb.tenant.consumption.sql_pods_cpu_secondsTotal amount of CPU used by SQL podscockroachdb
tenant_consumption_write_batchescockroachdb.tenant.consumption.write_batchesTotal number of KV write batchescockroachdb
tenant_consumption_write_bytescockroachdb.tenant.consumption.write_bytesTotal number of bytes written to KVcockroachdb
tenant_consumption_write_requestscockroachdb.tenant.consumption.write_requestsTotal number of KV write requestscockroachdb
timeseries_write_bytescockroachdb.timeseries.write.bytes.countTotal size in bytes of metric samples written to diskcockroachdb
timeseries_write_errorscockroachdb.timeseries.write.errors.countTotal errors encountered while attempting to write metrics to diskcockroachdb
timeseries_write_samplescockroachdb.timeseries.write.samples.countTotal number of metric samples written to diskcockroachdb
totalbytescockroachdb.totalbytesTotal number of bytes taken up by keys and values including non-live datacockroachdb
tscache_skl_pagescockroachdb.tscache.skl.pagesNumber of pages in the timestamp cachecockroachdb
tscache_skl_rotationscockroachdb.tscache.skl.rotations.countNumber of page rotations in the timestamp cachecockroachdb
txn_abortscockroachdb.txn.aborts.countNumber of aborted KV transactionscockroachdb
txn_commit_waitscockroachdb.txn.commit_waits.countNumber of KV transactions that had to commit-wait on commit in order to ensure linearizability. This generally happens to transactions writing to global ranges.cockroachdb
txn_commit_waits_before_commit_triggercockroachdb.txn.commit_waits.before_commit_trigger.countNumber of KV transactions that had to commit-wait on the server before committing because they had a commit triggercockroachdb
txn_commitscockroachdb.txn.commits.countNumber of committed KV transactions (including 1PC)cockroachdb
txn_commits1PCcockroachdb.txn.commits1PC.countNumber of KV transaction one-phase commitscockroachdb
txn_condensed_intent_spanscockroachdb.txn.condensed_intent_spans.countKV transactions that have exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). See also txn.condensed_intent_spans_gauge for a gauge of such transactions currently running.cockroachdb
txn_condensed_intent_spans_gaugecockroachdb.txn.condensed_intent_spans_gaugeKV transactions currently running that have exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). See also txn.condensed_intent_spans for a perpetual counter/rate.cockroachdb
txn_condensed_intent_spans_rejectedcockroachdb.txn.condensed_intent_spans_rejected.countKV transactions that have been aborted because they exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). Rejection is caused by kv.transaction.reject_over_max_intents_budget.cockroachdb
txn_durationscockroachdb.txn.durations.countKV transaction durationscockroachdb
txn_parallelcommitscockroachdb.txn.parallelcommits.countNumber of KV transaction parallel commitscockroachdb
txn_parallelcommits_auto_retriescockroachdb.txn.parallelcommits.auto_retries.countNumber of commit tries after successful failed parallel commit attemptscockroachdb
txn_refresh_auto_retriescockroachdb.txn.refresh.auto_retries.countNumber of request retries after successful client-side refreshescockroachdb
txn_refresh_failcockroachdb.txn.refresh.fail.countNumber of failed client-side transaction refreshescockroachdb
txn_refresh_fail_with_condensed_spanscockroachdb.txn.refresh.fail_with_condensed_spans.countNumber of failed client-side refreshes for transactions whose read tracking lost fidelity because of condensing. Such a failure could be a false conflict. Failures counted here are also counted in txn.refresh.fail, and the respective transactions are also counted in txn.refresh.memory_limit_exceeded.cockroachdb
txn_refresh_memory_limit_exceededcockroachdb.txn.refresh.memory_limit_exceeded.countNumber of transaction which exceed the refresh span bytes limit, causing their read spans to be condensedcockroachdb
txn_refresh_successcockroachdb.txn.refresh.success.countNumber of successful client-side transaction refreshes. A refresh may be preemptive or reactive. A reactive refresh is performed after a request throws an error because a refresh is needed for it to succeed. In these cases, the request will be re-issued as an auto-retry (see txn.refresh.auto_retries) after the refresh succeeds.cockroachdb
txn_refresh_success_server_sidecockroachdb.txn.refresh.success_server_side.countNumber of successful server-side transaction refreshescockroachdb
txn_restartscockroachdb.txn.restarts.countNumber of restarted KV transactionscockroachdb
txn_restarts_asyncwritefailurecockroachdb.txn.restarts.asyncwritefailure.countNumber of restarts due to async consensus writes that failed to leave intentscockroachdb
txn_restarts_commitdeadlineexceededcockroachdb.txn.restarts.commitdeadlineexceeded.countNumber of restarts due to a transaction exceeding its deadlinecockroachdb
txn_restarts_readwithinuncertaintycockroachdb.txn.restarts.readwithinuncertainty.countNumber of restarts due to reading a new value within the uncertainty intervalcockroachdb
txn_restarts_serializablecockroachdb.txn.restarts.serializable.countNumber of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLEcockroachdb
txn_restarts_txnabortedcockroachdb.txn.restarts.txnaborted.countNumber of restarts due to an abort by a concurrent transaction (usually due to deadlock)cockroachdb
txn_restarts_txnpushcockroachdb.txn.restarts.txnpush.countNumber of restarts due to a transaction push failurecockroachdb
txn_restarts_unknowncockroachdb.txn.restarts.unknown.countNumber of restarts due to a unknown reasonscockroachdb
txn_restarts_writetoooldcockroachdb.txn.restarts.writetooold.countNumber of restarts due to a concurrent writer committing firstcockroachdb
txn_rollbacks_async_failedcockroachdb.txn.rollbacks.async.failed.countNumber of KV transaction that failed to send abort asynchronously which is not always retriedcockroachdb
txn_rollbacks_failedcockroachdb.txn.rollbacks.failed.countNumber of KV transaction that failed to send final abortcockroachdb
txn_server_side_1PC_failurecockroachdb.txn.server_side.1PC.failure.countNumber of batches that attempted to commit using 1PC and failedcockroachdb
txn_server_side_1PC_successcockroachdb.txn.server_side.1PC.success.countNumber of batches that attempted to commit using 1PC and succeededcockroachdb
txn_server_side_retry_read_evaluation_failurecockroachdb.txn.server_side_retry.read_evaluation.failure.countNumber of read batches that were not successfully refreshed server sidecockroachdb
txn_server_side_retry_read_evaluation_successcockroachdb.txn.server_side_retry.read_evaluation.success.countNumber of read batches that were successfully refreshed server sidecockroachdb
txn_server_side_retry_uncertainty_interval_error_failurecockroachdb.txn.server_side_retry.uncertainty_interval_error.failure.countNumber of batches that ran into uncertainty interval errors that were not successfully refreshed server sidecockroachdb
txn_server_side_retry_uncertainty_interval_error_successcockroachdb.txn.server_side_retry.uncertainty_interval_error.success.countNumber of batches that ran into uncertainty interval errors that were successfully refreshed server sidecockroachdb
txn_server_side_retry_write_evaluation_failurecockroachdb.txn.server_side_retry.write_evaluation.failure.countNumber of write batches that were not successfully refreshed server sidecockroachdb
txn_server_side_retry_write_evaluation_successcockroachdb.txn.server_side_retry.write_evaluation.success.countNumber of write batches that were successfully refreshed server sidecockroachdb
txnrecovery_attempts_pendingcockroachdb.txnrecovery.attempts.pendingNumber of transaction recovery attempts currently in-flightcockroachdb
txnrecovery_failurescockroachdb.txnrecovery.failures.countNumber of transaction recovery attempts that failedcockroachdb
txnrecovery_successes_abortedcockroachdb.txnrecovery.successes.aborted.countNumber of transaction recovery attempts that aborted a transactioncockroachdb
txnrecovery_successes_committedcockroachdb.txnrecovery.successes.committed.countNumber of transaction recovery attempts that committed a transactioncockroachdb
txnrecovery_successes_pendingcockroachdb.txnrecovery.successes.pending.countNumber of transaction recovery attempts that left a transaction pendingcockroachdb
txnwaitqueue_deadlocks_totalcockroachdb.txnwaitqueue.deadlocks_total.countNumber of deadlocks detected by the txn wait queuecockroachdb
txnwaitqueue_pushee_waitingcockroachdb.txnwaitqueue.pushee.waitingNumber of pushees on the txn wait queuecockroachdb
txnwaitqueue_pusher_slowcockroachdb.txnwaitqueue.pusher.slowThe total number of cases where a pusher waited more than the excessive wait thresholdcockroachdb
txnwaitqueue_pusher_wait_timecockroachdb.txnwaitqueue.pusher.wait_time.countHistogram of durations spent in queue by pusherscockroachdb
txnwaitqueue_pusher_waitingcockroachdb.txnwaitqueue.pusher.waitingNumber of pushers on the txn wait queuecockroachdb
txnwaitqueue_query_wait_timecockroachdb.txnwaitqueue.query.wait_time.countHistogram of durations spent in queue by queriescockroachdb
txnwaitqueue_query_waitingcockroachdb.txnwaitqueue.query.waitingNumber of transaction status queries waiting for an updated transaction recordcockroachdb
valbytescockroachdb.valbytesNumber of bytes taken up by valuescockroachdb
valcountcockroachdb.valcountCount of all valuescockroachdb
container.blockio.io_serviced_recursivecontainer.io.read.operationsNumber of IOs (bio) issued to the disk by the group and descendant groups (Only available with cgroups v1).operation: readdockerstats
container.blockio.io_serviced_recursivecontainer.io.write.operationsNumber of IOs (bio) issued to the disk by the group and descendant groups (Only available with cgroups v1).operation: writedockerstats
container.cpu.throttling_data.throttled_periodscontainer.cpu.throttled.periodsNumber of periods when the container hits its throttling limit.dockerstats
container.cpu.throttling_data.throttled_timecontainer.cpu.throttledAggregate time the container was throttled.dockerstats
container.cpu.usage.systemcontainer.cpu.systemSystem CPU usage, as reported by docker.dockerstats
container.cpu.usage.totalcontainer.cpu.usageTotal CPU time consumed.dockerstats
container.cpu.usage.usermodecontainer.cpu.userTime spent by tasks of the cgroup in user mode (Linux). Time spent by all container processes in user mode (Windows).dockerstats
container.memory.active_anoncontainer.memory.kernelThe amount of anonymous memory that has been identified as active by the kernel.dockerstats
container.memory.hierarchical_memory_limitcontainer.memory.limitThe maximum amount of physical memory that can be used by the processes of this control group (Only available with cgroups v1).dockerstats
container.memory.rsskubernetes.memory.rssThe amount of memory that doesn’t correspond to anything on disk: stacks, heaps, and anonymous memory maps (Only available with cgroups v1).dockerstats
container.memory.total_cachecontainer.memory.cacheTotal amount of memory used by the processes of this cgroup (and descendants) that can be associated with a block on a block device. Also accounts for memory used by tmpfs (Only available with cgroups v1).dockerstats
container.memory.usage.limitcontainer.memory.soft_limitMemory limit of the container.dockerstats
container.memory.usage.totalcontainer.memory.usageMemory usage of the container. This excludes the cache.dockerstats
container.network.io.usage.rx_bytescontainer.net.rcvdBytes received by the container.dockerstats
container.network.io.usage.rx_packetscontainer.net.rcvd.packetsPackets received.dockerstats
container.network.io.usage.tx_bytescontainer.net.sentBytes sent.dockerstats
container.network.io.usage.tx_packetscontainer.net.sent.packetsPackets sent.dockerstats
jvm.gc.collections.countjvm.gc.major_collection_count{type: GarbageCollector}The total number of garbage collections that have occurredname: MarkSweepCompact, PS MarkSweep, ConcurrentMarkSweep, G1 Mixed Generation, G1 Old Generation, Shenandoah Cycles, ZGCelasticsearch
jvm.gc.collections.countjvm.gc.minor_collection_count{type: GarbageCollector}The total number of garbage collections that have occurredname: Copy, PS Scavenge, ParNew, G1 Young Generationelasticsearch
jvm.gc.collections.elapsedjvm.gc.major_collection_time{type: GarbageCollector}The approximate accumulated collection elapsed timename: MarkSweepCompact, PS MarkSweep, ConcurrentMarkSweep, G1 Mixed Generation, G1 Old Generation, Shenandoah Cycles, ZGCelasticsearch
jvm.gc.collections.elapsedjvm.gc.minor_collection_time{type: GarbageCollector}The approximate accumulated collection elapsed timename: Copy, PS Scavenge, ParNew, G1 Young Generationelasticsearch
haproxy.bytes.inputhaproxy.backend.bytes.in.countBytes in. Corresponds to HAProxy’s bin metric.haproxy.service_name: BACKENDhaproxy
haproxy.bytes.inputhaproxy.frontend.bytes.in.countBytes in. Corresponds to HAProxy’s bin metric.haproxy.service_name: FRONTENDhaproxy
haproxy.bytes.outputhaproxy.backend.bytes.out.countBytes out. Corresponds to HAProxy’s bout metric.haproxy.service_name: BACKENDhaproxy
haproxy.bytes.outputhaproxy.frontend.bytes.out.countBytes out. Corresponds to HAProxy’s bout metric.haproxy.service_name: FRONTENDhaproxy
haproxy.clients.canceledhaproxy.backend.client.aborts.countNumber of data transfers aborted by the client. Corresponds to HAProxy’s cli_abrt metrichaproxy
haproxy.compression.bypasshaproxy.backend.http.comp.bytes.bypassed.countNumber of bytes that bypassed the HTTP compressor (CPU/BW limit). Corresponds to HAProxy’s comp_byp metric.haproxy
haproxy.compression.counthaproxy.backend.http.comp.responses.countNumber of HTTP responses that were compressed. Corresponds to HAProxy’s comp_rsp metric.haproxy
haproxy.compression.inputhaproxy.backend.http.comp.bytes.in.countNumber of HTTP response bytes fed to the compressor. Corresponds to HAProxy’s comp_in metric.haproxy
haproxy.compression.outputhaproxy.backend.http.comp.bytes.out.countNumber of HTTP response bytes emitted by the compressor. Corresponds to HAProxy’s comp_out metric.haproxy
haproxy.connections.totalhaproxy.frontend.connections.countCumulative number of connections (frontend). Corresponds to HAProxy’s conn_tot metric.haproxy
haproxy.failed_checkshaproxy.server.check.failures.countNumber of failed checks. (Only counts checks failed when the server is up). Corresponds to HAProxy’s chkfail metric.haproxy
haproxy.requests.deniedhaproxy.backend.requests.denied.countRequests denied because of security concerns. Corresponds to HAProxy’s dreq metrichaproxy.service_name: BACKENDhaproxy
haproxy.requests.deniedhaproxy.frontend.requests.denied.countRequests denied because of security concerns. Corresponds to HAProxy’s dreq metrichaproxy.service_name: FRONTENDhaproxy
haproxy.requests.errorshaproxy.frontend.request.errors.countCumulative number of request errors. Corresponds to HAProxy’s ereq metric.haproxy.service_name: FRONTENDhaproxy
haproxy.requests.totalhaproxy.backend.http.requests.countTotal number of HTTP requests received. Corresponds to HAProxy’s req_tot, hrsp_1xx, hrsp_2xx, hrsp_3xx, hrsp_4xx, hrsp_5xx and hrsp_other metrics.haproxy.service_name: BACKENDhaproxy
haproxy.requests.totalhaproxy.frontend.http.requests.countTotal number of HTTP requests received. Corresponds to HAProxy’s req_tot, hrsp_1xx, hrsp_2xx, hrsp_3xx, hrsp_4xx, hrsp_5xx and hrsp_other metrics.haproxy.service_name: FRONTENDhaproxy
haproxy.responses.deniedhaproxy.frontend.responses.denied.countResponses denied because of security concerns. Corresponds to HAProxy’s dresp metrichaproxy.service_name: FRONTENDhaproxy
haproxy.responses.deniedhaproxy.backend.responses.denied.countResponses denied because of security concerns. Corresponds to HAProxy’s dresp metrichaproxy.service_name: BACKENDhaproxy
haproxy.responses.errorshaproxy.backend.response.errors.countCumulative number of response errors. Corresponds to HAProxy’s eresp metric, srv_abrt will be counted here also.haproxy.service_name: BACKENDhaproxy
haproxy.server_selected.totalhaproxy.server.loadbalanced.countNumber of times a server was selected, either for new sessions or when re-dispatching. Corresponds to HAProxy’s lbtot metric.haproxy
haproxy.sessions.counthaproxy.server.sessions.countCurrent sessions. Corresponds to HAProxy’s scur metric.haproxy
haproxy.sessions.totalhaproxy.frontend.sessions.countCumulative number of sessions. Corresponds to HAProxy’s stot metric.haproxy.service_name: FRONTENDhaproxy
haproxy.sessions.totalhaproxy.backend.sessions.countCumulative number of sessions. Corresponds to HAProxy’s stot metric.haproxy.service_name: BACKENDhaproxy
system.cpu.load_average.15msystem.load.15Average CPU Load over 15 minutes.host
system.cpu.load_average.1msystem.load.1Average CPU Load over 1 minute.host
system.cpu.load_average.5msystem.load.5Average CPU Load over 5 minutes.host
system.cpu.utilizationsystem.cpu.idleDifference in system.cpu.time since the last measurement per logical CPU, divided by the elapsed time (value in interval [0,1]).state: idle× 100host
system.cpu.utilizationsystem.cpu.iowaitDifference in system.cpu.time since the last measurement per logical CPU, divided by the elapsed time (value in interval [0,1]).state: wait× 100host
system.cpu.utilizationsystem.cpu.stolenDifference in system.cpu.time since the last measurement per logical CPU, divided by the elapsed time (value in interval [0,1]).state: steal× 100host
system.cpu.utilizationsystem.cpu.systemDifference in system.cpu.time since the last measurement per logical CPU, divided by the elapsed time (value in interval [0,1]).state: system× 100host
system.cpu.utilizationsystem.cpu.userDifference in system.cpu.time since the last measurement per logical CPU, divided by the elapsed time (value in interval [0,1]).state: user× 100host
system.filesystem.utilizationsystem.disk.in_useFraction of filesystem bytes used.host
system.filesystem.utilizationsystem.disk.in_useFraction of filesystem bytes used.host
system.memory.usagesystem.mem.totalBytes of memory in use.× 1048576host
system.memory.usagesystem.mem.usableBytes of memory in use.state: free, cached, buffered× 1048576host
system.network.iosystem.net.bytes_rcvdThe number of bytes transmitted and received.direction: receivehost
system.network.iosystem.net.bytes_sentThe number of bytes transmitted and received.direction: transmithost
system.paging.usagesystem.swap.freeSwap (unix) or pagefile (windows) usage.state: free× 1048576host
system.paging.usagesystem.swap.usedSwap (unix) or pagefile (windows) usage.state: used× 1048576host
iis.connection.activeiis.net.num_connectionsNumber of active connections.iis
iis.connection.anonymousiis.users.anonNumber of connections established anonymously.iis
iis.network.file.countiis.net.files_rcvdNumber of transmitted files.direction: receivediis
iis.network.file.countiis.net.files_sentNumber of transmitted files.direction: sentiis
iis.network.ioiis.net.bytes_rcvdTotal amount of bytes sent and received.direction: receivediis
iis.network.ioiis.net.bytes_sentTotal amount of bytes sent and received.direction: sentiis
iis.request.countiis.httpd_request_method.deleteTotal number of requests of a given type.request: deleteiis
iis.request.countiis.httpd_request_method.getTotal number of requests of a given type.request: getiis
iis.request.countiis.httpd_request_method.headTotal number of requests of a given type.request: headiis
iis.request.countiis.httpd_request_method.optionsTotal number of requests of a given type.request: optionsiis
iis.request.countiis.httpd_request_method.postTotal number of requests of a given type.request: postiis
iis.request.countiis.httpd_request_method.putTotal number of requests of a given type.request: putiis
iis.request.countiis.httpd_request_method.traceTotal number of requests of a given type.request: traceiis
jvm.gc.collections.countjvm.gc.major_collection_count{type: GarbageCollector}The total number of garbage collections that have occurredname: MarkSweepCompact, PS MarkSweep, ConcurrentMarkSweep, G1 Mixed Generation, G1 Old Generation, Shenandoah Cycles, ZGCjvm
jvm.gc.collections.countjvm.gc.minor_collection_count{type: GarbageCollector}The total number of garbage collections that have occurredname: Copy, PS Scavenge, ParNew, G1 Young Generationjvm
jvm.gc.collections.elapsedjvm.gc.major_collection_time{type: GarbageCollector}The approximate accumulated collection elapsed timename: MarkSweepCompact, PS MarkSweep, ConcurrentMarkSweep, G1 Mixed Generation, G1 Old Generation, Shenandoah Cycles, ZGCjvm
jvm.gc.collections.elapsedjvm.gc.minor_collection_time{type: GarbageCollector}The approximate accumulated collection elapsed timename: Copy, PS Scavenge, ParNew, G1 Young Generationjvm
k8s.node.memory.usagekubernetes.memory.usageMemory usage of the Node Note: Total memory usage of the Nodek8s
k8s.node.memory.usagekubernetes.memory.usageMemory usage of the Node Note: Total memory usage of the Nodek8s
k8s.pod.memory.usagekubernetes.memory.usageMemory usage of the Pod Note: Total memory usage of the Podk8s
k8s.pod.memory.usagekubernetes.memory.usageMemory usage of the Pod Note: Total memory usage of the Podk8s
k8s.container.cpu_limitkubernetes.cpu.limitsMaximum resource limit set for the container. See https://kubernetes.io/docs/reference/generated/kubernetes-api/v1.23/#resourcerequirements-v1-core for detailsk8scluster
k8s.container.cpu_requestkubernetes.cpu.requestsResource requested for the container. See https://kubernetes.io/docs/reference/generated/kubernetes-api/v1.23/#resourcerequirements-v1-core for detailsk8scluster
k8s.container.memory_requestkubernetes.memory.requestsResource requested for the container. See https://kubernetes.io/docs/reference/generated/kubernetes-api/v1.23/#resourcerequirements-v1-core for detailsk8scluster
k8s.job.active_podskubernetes.pods.runningThe number of actively running pods for a jobk8scluster
kafka.consumer.bytes-consumed-ratekafka.consumer.bytes_consumedThe average number of bytes consumed per secondRename attribute key client-id to clientkafka
kafka.consumer.fetch-size-avgkafka.consumer.fetch_size_avgThe average number of bytes fetched per requestRename attribute key client-id to clientkafka
kafka.consumer.records-consumed-ratekafka.consumer.records_consumedThe average number of records consumed per secondRename attribute key client-id to clientkafka
kafka.consumer.total.bytes-consumed-ratekafka.consumer.bytes_inThe average number of bytes consumed for all topics per second.kafka
kafka.consumer.total.records-consumed-ratekafka.consumer.messages_inThe average number of records consumed for all topics per second.kafka
kafka.consumer_group.lagkafka.consumer_lagCurrent approximate lag of consumer group at partition of topicRename attribute key group to consumer_groupkafka
kafka.consumer_group.offsetkafka.consumer_offsetCurrent offset of the consumer group at partition of topicRename attribute key group to consumer_groupkafka
kafka.controller.active.countkafka.replication.active_controller_countController is active on brokerkafka
kafka.isr.operation.countkafka.replication.isr_expands.rateThe number of in-sync replica shrink and expand operationsoperation: expandkafka
kafka.isr.operation.countkafka.replication.isr_shrinks.rateThe number of in-sync replica shrink and expand operationsoperation: shrinkkafka
kafka.leader.election.ratekafka.replication.leader_elections.rateLeader election rate - increasing indicates broker failureskafka
kafka.logs.flush.time.countkafka.log.flush_rate.rateLog flush countkafka
kafka.max.lagkafka.replication.max_lagMax lag in messages between follower and leader replicaskafka
kafka.message.countkafka.messages_in.rateThe number of messages received by the brokerkafka
kafka.network.iokafka.net.bytes_in.rateThe bytes received or sent by the brokerstate: inkafka
kafka.network.iokafka.net.bytes_out.rateThe bytes received or sent by the brokerstate: outkafka
kafka.partition.countkafka.replication.partition_countThe number of partitions on the brokerkafka
kafka.partition.current_offsetkafka.broker_offsetCurrent offset of partition of topic.Rename attribute key group to consumer_groupkafka
kafka.partition.offlinekafka.replication.offline_partitions_countThe number of partitions offlinekafka
kafka.partition.under_replicatedkafka.replication.under_replicated_partitionsThe number of under replicated partitionskafka
kafka.producer.byte-ratekafka.producer.bytes_outThe average number of bytes sent per second for a topic.Rename attribute key client-id to clientkafka
kafka.producer.compression-ratekafka.producer.compression_rateThe average compression rate of record batches for a topic.Rename attribute key client-id to clientkafka
kafka.producer.io-wait-time-ns-avgkafka.producer.io_waitThe average length of time the I/O thread spent waiting for a socket ready for reads or writes.kafka
kafka.producer.outgoing-byte-ratekafka.producer.bytes_outThe average number of outgoing bytes sent per second to all servers.kafka
kafka.producer.record-error-ratekafka.producer.record_error_rateThe average per-second number of record sends that resulted in errors for a topic.Rename attribute key client-id to clientkafka
kafka.producer.record-retry-ratekafka.producer.record_retry_rateThe average per-second number of retried record sends for a topic.Rename attribute key client-id to clientkafka
kafka.producer.record-send-ratekafka.producer.record_send_rateThe average number of records sent per second for a topic.Rename attribute key client-id to clientkafka
kafka.producer.request-latency-avgkafka.producer.request_latency_avgThe average request latency.kafka
kafka.producer.request-ratekafka.producer.request_rateThe average number of requests sent per second.kafka
kafka.producer.response-ratekafka.producer.response_rateResponses received per second.kafka
kafka.purgatory.sizekafka.request.fetch_request_purgatory.sizeThe number of requests waiting in purgatorytype: fetchkafka
kafka.purgatory.sizekafka.request.producer_request_purgatory.sizeThe number of requests waiting in purgatorytype: producekafka
kafka.request.failedkafka.request.fetch.failed.rateThe number of requests to the broker resulting in a failuretype: fetchkafka
kafka.request.failedkafka.request.produce.failed.rateThe number of requests to the broker resulting in a failuretype: producekafka
kafka.request.queuekafka.request.channel.queue.sizeSize of the request queuekafka
kafka.request.time.99pkafka.request.fetch_consumer.time.99percentileThe 99th percentile time the broker has taken to service requeststype: fetchconsumerkafka
kafka.request.time.99pkafka.request.fetch_follower.time.99percentileThe 99th percentile time the broker has taken to service requeststype: fetchfollowerkafka
kafka.request.time.99pkafka.request.produce.time.99percentileThe 99th percentile time the broker has taken to service requeststype: producekafka
kafka.request.time.avgkafka.request.fetch_consumer.time.avgThe average time the broker has taken to service requeststype: fetchconsumerkafka
kafka.request.time.avgkafka.request.fetch_follower.time.avgThe average time the broker has taken to service requeststype: fetchfollowerkafka
kafka.request.time.avgkafka.request.produce.time.avgThe average time the broker has taken to service requeststype: producekafka
kafka.unclean.election.ratekafka.replication.unclean_leader_elections.rateUnclean leader election rate - increasing indicates broker failureskafka
container.filesystem.usagekubernetes.filesystem.usageContainer filesystem usagekubeletstats
container.filesystem.usagekubernetes.filesystem.usageContainer filesystem usagekubeletstats
container.memory.rsskubernetes.memory.rssContainer memory rsskubeletstats
k8s.node.filesystem.usagekubernetes.filesystem.usageNode filesystem usagekubeletstats
k8s.node.filesystem.usagekubernetes.filesystem.usageNode filesystem usagekubeletstats
k8s.node.memory.rsskubernetes.memory.rssNode memory rsskubeletstats
k8s.node.memory.usagekubernetes.memory.usageNode memory usagekubeletstats
k8s.node.memory.usagekubernetes.memory.usageNode memory usagekubeletstats
k8s.node.network.errorskubernetes.network.tx_errorsNode network errorsdirection: transmitkubeletstats
k8s.node.network.errorskubernetes.network.rx_errorsNode network errorsdirection: receivekubeletstats
k8s.node.network.iokubernetes.io.read_bytesNode network IOdirection: receivekubeletstats
k8s.node.network.iokubernetes.io.write_bytesNode network IOdirection: transmitkubeletstats
k8s.node.network.iokubernetes.network.rx_bytesNode network IOdirection: receivekubeletstats
k8s.node.network.iokubernetes.network.tx_bytesNode network IOdirection: transmitkubeletstats
k8s.pod.filesystem.usagekubernetes.filesystem.usagePod filesystem usagekubeletstats
k8s.pod.filesystem.usagekubernetes.filesystem.usagePod filesystem usagekubeletstats
k8s.pod.memory.node.utilizationkubernetes.memory.usage_pctPod memory utilization as a ratio of the node’s capacitykubeletstats
k8s.pod.memory.rsskubernetes.memory.rssPod memory rsskubeletstats
k8s.pod.memory.usagekubernetes.memory.usagePod memory usagekubeletstats
k8s.pod.memory.usagekubernetes.memory.usagePod memory usagekubeletstats
k8s.pod.network.errorskubernetes.network.tx_errorsPod network errorsdirection: transmitkubeletstats
k8s.pod.network.errorskubernetes.network.rx_errorsPod network errorsdirection: receivekubeletstats
k8s.pod.network.iokubernetes.network.rx_bytesPod network IOdirection: receivekubeletstats
k8s.pod.network.iokubernetes.network.tx_bytesPod network IOdirection: transmitkubeletstats
k8s.pod.network.iokubernetes.io.write_bytesPod network IOdirection: transmitkubeletstats
k8s.pod.network.iokubernetes.io.read_bytesPod network IOdirection: receivekubeletstats
mysql.buffer_pool.data_pagesmysql.innodb.buffer_pool_pages_dataThe number of data pages in the InnoDB buffer pool.mysql
mysql.buffer_pool.data_pagesmysql.innodb.buffer_pool_pages_dirtyThe number of data pages in the InnoDB buffer pool.status: dirtymysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_read_ahead_rndThe number of operations on the InnoDB buffer pool.operation: read_ahead_rndmysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_write_requestsThe number of operations on the InnoDB buffer pool.operation: write_requestsmysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_read_aheadThe number of operations on the InnoDB buffer pool.operation: read_aheadmysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_read_ahead_evictedThe number of operations on the InnoDB buffer pool.operation: read_ahead_evictedmysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_wait_freeThe number of operations on the InnoDB buffer pool.operation: wait_freemysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_read_requestsThe number of operations on the InnoDB buffer pool.operation: read_requestsmysql
mysql.buffer_pool.operationsmysql.innodb.buffer_pool_readsThe number of operations on the InnoDB buffer pool.operation: readsmysql
mysql.buffer_pool.page_flushesmysql.innodb.buffer_pool_pages_flushedThe number of requests to flush pages from the InnoDB buffer pool.mysql
mysql.buffer_pool.pagesmysql.innodb.buffer_pool_pages_freeThe number of pages in the InnoDB buffer pool.kind: freemysql
mysql.buffer_pool.pagesmysql.innodb.buffer_pool_pages_totalThe number of pages in the InnoDB buffer pool.mysql
mysql.buffer_pool.usagemysql.innodb.buffer_pool_dataThe number of bytes in the InnoDB buffer pool.mysql
mysql.buffer_pool.usagemysql.innodb.buffer_pool_dirtyThe number of bytes in the InnoDB buffer pool.status: dirtymysql
mysql.client.network.iomysql.performance.bytes_sentThe number of transmitted bytes between server and clients.kind: sentmysql
mysql.client.network.iomysql.performance.bytes_receivedThe number of transmitted bytes between server and clients.kind: receivedmysql
mysql.commandsmysql.performance.com_updateThe number of times each type of command has been executed.kind: updatemysql
mysql.commandsmysql.performance.com_insertThe number of times each type of command has been executed.kind: insertmysql
mysql.commandsmysql.performance.com_deleteThe number of times each type of command has been executed.kind: deletemysql
mysql.commandsmysql.performance.com_selectThe number of times each type of command has been executed.kind: selectmysql
mysql.double_writesmysql.innodb.dblwr_writesThe number of writes to the InnoDB doublewrite buffer.kind: writesmysql
mysql.double_writesmysql.innodb.dblwr_pages_writtenThe number of writes to the InnoDB doublewrite buffer.kind: pages_writtenmysql
mysql.handlersmysql.performance.handler_deleteThe number of requests to various MySQL handlers.kind: deletemysql
mysql.handlersmysql.performance.handler_commitThe number of requests to various MySQL handlers.kind: commitmysql
mysql.handlersmysql.performance.handler_read_keyThe number of requests to various MySQL handlers.kind: read_keymysql
mysql.handlersmysql.performance.handler_read_prevThe number of requests to various MySQL handlers.kind: read_prevmysql
mysql.handlersmysql.performance.handler_read_rndThe number of requests to various MySQL handlers.kind: read_rndmysql
mysql.handlersmysql.performance.handler_read_rnd_nextThe number of requests to various MySQL handlers.kind: read_rnd_nextmysql
mysql.handlersmysql.performance.handler_rollbackThe number of requests to various MySQL handlers.kind: rollbackmysql
mysql.handlersmysql.performance.handler_prepareThe number of requests to various MySQL handlers.kind: preparemysql
mysql.handlersmysql.performance.handler_read_nextThe number of requests to various MySQL handlers.kind: read_nextmysql
mysql.handlersmysql.performance.handler_writeThe number of requests to various MySQL handlers.kind: writemysql
mysql.handlersmysql.performance.handler_updateThe number of requests to various MySQL handlers.kind: updatemysql
mysql.handlersmysql.performance.handler_read_firstThe number of requests to various MySQL handlers.kind: read_firstmysql
mysql.joinsmysql.performance.select_full_joinThe number of joins that perform table scans.kind: fullmysql
mysql.joinsmysql.performance.select_full_range_joinThe number of joins that perform table scans.kind: full_rangemysql
mysql.joinsmysql.performance.select_rangeThe number of joins that perform table scans.kind: rangemysql
mysql.joinsmysql.performance.select_range_checkThe number of joins that perform table scans.kind: range_checkmysql
mysql.joinsmysql.performance.select_scanThe number of joins that perform table scans.kind: scanmysql
mysql.locksmysql.performance.table_locks_immediateThe number of MySQL locks.kind: immediatemysql
mysql.locksmysql.performance.table_locks_waitedThe number of MySQL locks.kind: waitedmysql
mysql.log_operationsmysql.innodb.log_write_requestsThe number of InnoDB log operations.operation: write_requestsmysql
mysql.log_operationsmysql.innodb.log_writesThe number of InnoDB log operations.operation: writesmysql
mysql.log_operationsmysql.innodb.log_waitsThe number of InnoDB log operations.operation: waitsmysql
mysql.operationsmysql.innodb.data_fsyncsThe number of InnoDB operations.operation: fsyncsmysql
mysql.page_operationsmysql.innodb.pages_createdThe number of InnoDB page operations.operation: createdmysql
mysql.page_operationsmysql.innodb.pages_readThe number of InnoDB page operations.operation: readmysql
mysql.page_operationsmysql.innodb.pages_writtenThe number of InnoDB page operations.operation: writtenmysql
mysql.replica.time_behind_sourcemysql.replication.seconds_behind_sourceThis field is an indication of how “late” the replica is.mysql
mysql.row_locksmysql.innodb.current_row_locksThe number of InnoDB row locks.mysql
mysql.row_locksmysql.innodb.row_lock_current_waitsThe number of InnoDB row locks.kind: waitsmysql
mysql.row_operationsmysql.innodb.rows_updatedThe number of InnoDB row operations.operation: updatedmysql
mysql.row_operationsmysql.innodb.rows_readThe number of InnoDB row operations.operation: readmysql
mysql.row_operationsmysql.innodb.rows_insertedThe number of InnoDB row operations.operation: insertedmysql
mysql.row_operationsmysql.innodb.rows_deletedThe number of InnoDB row operations.operation: deletedmysql
mysql.sortsmysql.performance.sort_scanThe number of MySQL sorts.kind: scanmysql
mysql.sortsmysql.performance.sort_rowsThe number of MySQL sorts.kind: rowsmysql
mysql.sortsmysql.performance.sort_merge_passesThe number of MySQL sorts.kind: merge_passesmysql
mysql.sortsmysql.performance.sort_rangeThe number of MySQL sorts.kind: rangemysql
mysql.table_open_cachemysql.performance.table_cache_hitsThe number of hits, misses or overflows for open tables cache lookups.status: hitmysql
mysql.table_open_cachemysql.performance.table_cache_missesThe number of hits, misses or overflows for open tables cache lookups.status: missmysql
mysql.threadsmysql.performance.threads_runningThe state of MySQL threads.kind: runningmysql
mysql.threadsmysql.performance.threads_cachedThe state of MySQL threads.kind: cachedmysql
mysql.threadsmysql.performance.threads_connectedThe state of MySQL threads.kind: connectedmysql
mysql.threadsmysql.performance.threads_createdThe state of MySQL threads.kind: createdmysql
mysql.tmp_resourcesmysql.performance.created_tmp_tablesThe number of created temporary resources.resource: tablesmysql
mysql.tmp_resourcesmysql.performance.created_tmp_disk_tablesThe number of created temporary resources.resource: disk_tablesmysql
mysql.tmp_resourcesmysql.performance.created_tmp_filesThe number of created temporary resources.resource: filesmysql
nginx.connections_acceptednginx.connections.accepted_countThe total number of accepted client connectionsnginx
nginx.connections_currentnginx.connections.idleThe current number of nginx connections by statestate: waitingnginx
nginx.connections_currentnginx.net.connectionsThe current number of nginx connections by statestate: activenginx
nginx.connections_currentnginx.net.waitingThe current number of nginx connections by statestate: waitingnginx
nginx.requestsnginx.requests.total_countTotal number of requests made to the server since it startednginx
container.blockio.io_service_bytes_recursive.readcontainer.io.readNumber of bytes transferred from the disk by the containerpodman
container.blockio.io_service_bytes_recursive.writecontainer.io.writeNumber of bytes transferred to the disk by the containerpodman
container.cpu.usage.systemcontainer.cpu.systemSystem CPU usage.podman
container.cpu.usage.totalcontainer.cpu.usageTotal CPU time consumed.podman
container.memory.usage.limitcontainer.memory.soft_limitMemory limit of the container.podman
container.memory.usage.totalcontainer.memory.usageMemory usage of the container.podman
container.network.io.usage.rx_bytescontainer.net.rcvdBytes received by the container.podman
container.network.io.usage.tx_bytescontainer.net.sentBytes sent by the container.podman
system.cpu.utilizationsystem.cpu.idleDifference in system.cpu.time since the last measurement, divided by the elapsed time and number of logical CPUsstate: idle× 100system
system.cpu.utilizationsystem.cpu.iowaitDifference in system.cpu.time since the last measurement, divided by the elapsed time and number of logical CPUsstate: wait× 100system
system.cpu.utilizationsystem.cpu.stolenDifference in system.cpu.time since the last measurement, divided by the elapsed time and number of logical CPUsstate: steal× 100system
system.cpu.utilizationsystem.cpu.systemDifference in system.cpu.time since the last measurement, divided by the elapsed time and number of logical CPUsstate: system× 100system
system.cpu.utilizationsystem.cpu.userDifference in system.cpu.time since the last measurement, divided by the elapsed time and number of logical CPUsstate: user× 100system
system.filesystem.utilizationsystem.disk.in_useThe amount of disk space in use as a percent of the total.system
system.filesystem.utilizationsystem.disk.in_useThe amount of disk space in use as a fraction of the total.system
system.memory.usagesystem.mem.totalReports memory in use by state. Note: The sum over all system.memory.state values SHOULD equal the total memory available on the system, that is system.memory.limit.× 1048576system
system.memory.usagesystem.mem.usableReports memory in use by state. Note: The sum over all system.memory.state values SHOULD equal the total memory available on the system, that is system.memory.limit.state: free, cached, buffered× 1048576system
system.network.iosystem.net.bytes_rcvdThe number of bytes received on a device per second.direction: receivesystem
system.network.iosystem.net.bytes_sentThe number of bytes sent from a device per second.direction: transmitsystem
system.paging.usagesystem.swap.freeUnix swap or windows pagefile usagestate: free× 1048576system
system.paging.usagesystem.swap.usedUnix swap or windows pagefile usagestate: used× 1048576system

Further reading

PREVIEWING: guacbot/translation-pipeline