跳转至

CockroachDB

·


CockroachDB 采集器用于采集 CockroachDB 相关的指标数据,目前只支持 Prometheus 格式的数据

已测试的版本:

  • CockroachDB 19.2
  • CockroachDB 20.2
  • CockroachDB 21.2
  • CockroachDB 22.2
  • CockroachDB 23.2.4

配置

采集器配置

进入 DataKit 安装目录下的 conf.d/db 目录,复制 cockroachdb.conf.sample 并命名为 cockroachdb.conf。示例如下:

[[inputs.prom]]
  ## Collector alias.
  source = "cockroachdb"

  ## Exporter URLs.
  urls = ["http://localhost:8080/_status/vars"]

  ## (Optional) Collect interval: (defaults to "30s").
  # interval = "30s"

  ## (Optional) Timeout: (defaults to "30s").
  # timeout = "30s"

  ## Stream Size. 
  ## The source stream segmentation size, (defaults to 1).
  ## 0 source stream undivided. 
  stream_size = 0

  ## Unix Domain Socket URL. Using socket to request data when not empty.
  # uds_path = ""

  ## Ignore URL request errors.
  # ignore_req_err = false

  ## Collect data output.
  ## Fill this when want to collect the data to local file nor center.
  ## After filling, could use 'datakit debug --prom-conf /path/to/this/conf' to debug local storage measurement set.
  ## Using '--prom-conf' when priority debugging data in 'output' path.
  # output = "/abs/path/to/file"

  ## Collect data upper limit as bytes.
  ## Only available when set output to local file.
  ## If collect data exceeded the limit, the data would be dropped.
  ## Default is 32MB.
  # max_file_size = 0

  ## Metrics type whitelist. Optional: counter, gauge, histogram, summary
  ## Example: metric_types = ["counter", "gauge"], only collect 'counter' and 'gauge'.
  ## Default collect all.
  # metric_types = []

  ## Metrics name whitelist.
  ## Regex supported. Multi supported, conditions met when one matched.
  ## Collect all if empty.
  # metric_name_filter = ["cpu"]

  ## Metrics name blacklist.
  ## If a word both in blacklist and whitelist, blacklist priority.
  ## Regex supported. Multi supported, conditions met when one matched.
  ## Collect all if empty.
  # metric_name_filter_ignore = ["foo","bar"]

  ## Measurement prefix.
  ## Add prefix to measurement set name.
  measurement_prefix = ""

  ## Measurement name.
  ## If measurement_name is empty, split metric name by '_', the first field after split as measurement set name, the rest as current metric name.
  ## If measurement_name is not empty, using this as measurement set name.
  ## Always add 'measurement_prefix' prefix at last.
  measurement_name = "cockroachdb"

  ## TLS configuration.
  # tls_open = false
  # tls_ca = "/tmp/ca.crt"
  # tls_cert = "/tmp/peer.crt"
  # tls_key = "/tmp/peer.key"

  ## Set to 'true' to enable election.
  election = true

  ## disable setting host tag for this input
  disable_host_tag = false

  ## disable setting instance tag for this input
  disable_instance_tag = false

  ## disable info tag for this input
  disable_info_tag = false

  ## Ignore tags. Multi supported.
  ## The matched tags would be dropped, but the item would still be sent.
  # tags_ignore = ["xxxx"]

  ## Customize authentification. For now support Bearer Token only.
  ## Filling in 'token' or 'token_file' is acceptable.
  # [inputs.prom.auth]
    # type = "bearer_token"
    # token = "xxxxxxxx"
    # token_file = "/tmp/token"

  ## Customize measurement set name.
  ## Treat those metrics with prefix as one set.
  ## Prioritier over 'measurement_name' configuration.
  # [[inputs.prom.measurements]]
    # prefix = "sql_"
    # name = "cockroachdb_sql"

  # [[inputs.prom.measurements]]
    # prefix = "txn_"
    # name = "cockroachdb_txn"

  ## Not collecting those data when tag matched.
  # [inputs.prom.ignore_tag_kv_match]
    # key1 = [ "val1.*", "val2.*"]
    # key2 = [ "val1.*", "val2.*"]

  ## Add HTTP headers to data pulling (Example basic authentication).
  # [inputs.prom.http_headers]
    # Authorization = "Basic bXl0b21jYXQ="

  ## Rename tag key in prom data.
  [inputs.prom.tags_rename]
    overwrite_exist_tags = false

  # [inputs.prom.tags_rename.mapping]
    # tag1 = "new-name-1"
    # tag2 = "new-name-2"

  ## Send collected metrics to center as log.
  ## When 'service' field is empty, using 'service tag' as measurement set name.
  [inputs.prom.as_logging]
    enable = false
    service = "service_name"

  ## Customize tags.
  # [inputs.prom.tags]
    # some_tag = "some_value"
    # more_tag = "some_other_value"

配置好后,重启 DataKit 即可。

指标

cockroachdb

  • 标签
Tag Description
host Host name.
instance Instance endpoint.
le Histogram quantile.
node_id Node id.
store Store id.
  • 指标列表
Metric Description
abortspanbytes Number of bytes in the abort span.
Type: float
Unit: digital,B
addsstable_applications [OpenMetrics v1] Number of SSTable ingestion applied (i.e. applied by Replicas).
Type: float
Unit: count
addsstable_applications_count [OpenMetrics v2] Number of SSTable ingestion applied (i.e. applied by Replicas).
Type: float
Unit: count
addsstable_copies [OpenMetrics v1] number of SSTable ingestion that required copying files during application.
Type: float
Unit: count
addsstable_copies_count [OpenMetrics v2] number of SSTable ingestion that required copying files during application.
Type: float
Unit: count
addsstable_delay_count Amount by which evaluation of AddSSTable requests was delayed.
Type: float
Unit: time,ns
addsstable_delay_enginebackpressure Amount by which evaluation of AddSSTable requests was delayed by storage-engine back pressure.
Type: float
Unit: time,ns
addsstable_proposals [OpenMetrics v1] Number of SSTable ingestion proposed (i.e. sent to Raft by lease holders).
Type: float
Unit: count
addsstable_proposals_count [OpenMetrics v2] Number of SSTable ingestion proposed (i.e. sent to Raft by lease holders).
Type: float
Unit: count
admission_admitted_elastic_cpu Number of requests admitted.
Type: float
Unit: count
admission_admitted_elastic_cpu_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_elastic_cpu_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv [OpenMetrics v1] Number of KV requests admitted.
Type: float
Unit: count
admission_admitted_kv_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_count [OpenMetrics v2] Number of KV requests admitted.
Type: float
Unit: count
admission_admitted_kv_high_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores [OpenMetrics v1] Number of KV stores requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_count [OpenMetrics v2] Number of KV stores requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_high_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_kv_stores_ttl_low_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_kv_response [OpenMetrics v1] Number of SQL KV response requests admitted.
Type: float
Unit: count
admission_admitted_sql_kv_response_count [OpenMetrics v2] Number of SQL KV response requests admitted.
Type: float
Unit: count
admission_admitted_sql_kv_response_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_kv_response_locking_pri
Type: float
Unit: count
admission_admitted_sql_kv_response_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_leaf_start [OpenMetrics v1] Number of SQL leaf start requests admitted.
Type: float
Unit: count
admission_admitted_sql_leaf_start_count [OpenMetrics v2] Number of SQL leaf start requests admitted.
Type: float
Unit: count
admission_admitted_sql_leaf_start_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_leaf_start_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_root_start [OpenMetrics v1] Number of SQL root start requests admitted.
Type: float
Unit: count
admission_admitted_sql_root_start_count [OpenMetrics v2] Number of SQL root start requests admitted.
Type: float
Unit: count
admission_admitted_sql_root_start_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_root_start_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_sql_response [OpenMetrics v1] Number of Distributed SQL response requests admitted.
Type: float
Unit: count
admission_admitted_sql_sql_response_count [OpenMetrics v2] Number of Distributed SQL response requests admitted.
Type: float
Unit: count
admission_admitted_sql_sql_response_locking_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_admitted_sql_sql_response_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_elastic_cpu_acquired_nanos Total CPU nanoseconds acquired by elastic work.
Type: float
Unit: time,ns
admission_elastic_cpu_available_nanos Instantaneous available CPU nanoseconds per second ignoring utilization limit.
Type: float
Unit: time,ns
admission_elastic_cpu_max_available_nanos Maximum available CPU nanoseconds per second ignoring utilization limit.
Type: float
Unit: time,ns
admission_elastic_cpu_nanos_exhausted_duration Total duration when elastic CPU nanoseconds were exhausted, in micros.
Type: float
Unit: count
admission_elastic_cpu_over_limit_durations_bucket Measurement of how much over the prescribed limit elastic requests ran (not recorded if requests don't run over).
Type: float
Unit: time,ns
admission_elastic_cpu_over_limit_durations_count Measurement of how much over the prescribed limit elastic requests ran (not recorded if requests don't run over).
Type: float
Unit: time,ns
admission_elastic_cpu_over_limit_durations_sum Measurement of how much over the prescribed limit elastic requests ran (not recorded if requests don't run over).
Type: float
Unit: time,ns
admission_elastic_cpu_pre_work_nanos Total CPU nanoseconds spent doing pre-work, before doing elastic work.
Type: float
Unit: time,ns
admission_elastic_cpu_returned_nanos Total CPU nanoseconds returned by elastic work.
Type: float
Unit: time,ns
admission_elastic_cpu_utilization CPU utilization by elastic work.
Type: float
Unit: percent,percent
admission_elastic_cpu_utilization_limit Utilization limit set for the elastic CPU work.
Type: float
Unit: percent,percent
admission_errored_elastic_cpu Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_elastic_cpu_bulk_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_elastic_cpu_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv [OpenMetrics v1] Number of KV requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_errored_kv_countt [OpenMetrics v2] Number of KV requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_high_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores [OpenMetrics v1] Number of KV stores requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_bulk_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_countt [OpenMetrics v2] Number of KV stores requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_high_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_kv_stores_ttl_low_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_kv_response [OpenMetrics v1] Number of SQL KV requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_kv_response_count [OpenMetrics v2] Number of SQL KV requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_kv_response_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_kv_response_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_leaf_start [OpenMetrics v1] Number of SQL leaf start requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_leaf_start_count [OpenMetrics v2] Number of SQL leaf start requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_leaf_start_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_leaf_start_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_root_start [OpenMetrics v1] Number of SQL root start requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_root_start_count [OpenMetrics v2] Number of SQL root start requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_root_start_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_root_start_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_sql_response [OpenMetrics v1] Number of Distributed SQL requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_sql_response_count [OpenMetrics v2] Number of Distributed SQL start requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_sql_response_locking_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_errored_sql_sql_response_normal_pri Number of requests not admitted due to error.
Type: float
Unit: count
admission_granter_cpu_load_long_period_duration_kv Total duration when CPULoad was being called with a long period, in micros.
Type: float
Unit: count
admission_granter_cpu_load_short_period_duration_kv Total duration when CPULoad was being called with a short period, in micros.
Type: float
Unit: count
admission_granter_elastic_io_tokens_available_kv Number of tokens available.
Type: float
Unit: count
admission_granter_io_tokens_available_kv Number of tokens available.
Type: float
Unit: count
admission_granter_io_tokens_bypassed_kv Total number of tokens taken by work bypassing admission control (for example, follower writes without flow control).
Type: float
Unit: count
admission_granter_io_tokens_exhausted_duration_kv [OpenMetrics v1] Total duration when IO tokens were exhausted, in micros.
Type: float
Unit: count
admission_granter_io_tokens_exhausted_duration_kv_count [OpenMetrics v2] Total duration when IO tokens were exhausted, in micros.
Type: float
Unit: count
admission_granter_io_tokens_returned_kv Total number of tokens returned.
Type: float
Unit: count
admission_granter_io_tokens_taken_kv Total number of tokens taken.
Type: float
Unit: count
admission_granter_slot_adjuster_decrements_kv Number of decrements of the total KV slots.
Type: float
Unit: count
admission_granter_slot_adjuster_increments_kv Number of increments of the total KV slots.
Type: float
Unit: count
admission_granter_slots_exhausted_duration_kv Total duration when KV slots were exhausted, in micros.
Type: float
Unit: count
admission_granter_total_slots_kv [OpenMetrics v1 & v2] Total slots for KV work.
Type: float
Unit: count
admission_granter_used_slots_kv [OpenMetrics v1 & v2] Used slots for KV work.
Type: float
Unit: count
admission_granter_used_slots_sql_leaf_start [OpenMetrics v1 & v2] Used slots for SQL leaf start work.
Type: float
Unit: count
admission_granter_used_slots_sql_root_start [OpenMetrics v1 & v2] Used slots for SQL root start work.
Type: float
Unit: count
admission_io_overload 1-normalized float indicating whether IO admission control considers the store as overloaded with respect to compaction out of L0 (considers sub-level and file counts).
Type: float
Unit: count
admission_l0_compacted_bytes_kv Total bytes compacted out of L0 (used to generate IO tokens).
Type: float
Unit: count
admission_l0_tokens_produced_kv Total number of generated token of L0.
Type: float
Unit: count
admission_raft_paused_replicas Number 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.
Type: float
Unit: count
admission_raft_paused_replicas_dropped_msgs Number of messages dropped instead of being sent to paused replicas.The messages are dropped to help these replicas to recover from I/O overload.
Type: float
Unit: count
admission_requested_elastic_cpu Number of requests.
Type: float
Unit: count
admission_requested_elastic_cpu_bulk_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_elastic_cpu_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv [OpenMetrics v1] Number of KV admission requests.
Type: float
Unit: count
admission_requested_kv_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_requested_kv_count [OpenMetrics v2] Number of KV admission requests.
Type: float
Unit: count
admission_requested_kv_high_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_stores [OpenMetrics v2] Number of KV stores admission requests.
Type: float
Unit: count
admission_requested_kv_stores_bulk_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_stores_high_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_stores_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_stores_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_kv_stores_ttl_low_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_kv_response [OpenMetrics v1] Number of SQL KV admission requests.
Type: float
Unit: count
admission_requested_sql_kv_response_count [OpenMetrics v2] Number of SQL KV admission requests.
Type: float
Unit: count
admission_requested_sql_kv_response_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_kv_response_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_leaf_start [OpenMetrics v1] Number of SQL leaf start admission requests.
Type: float
Unit: count
admission_requested_sql_leaf_start_count [OpenMetrics v2] Number of SQL leaf start admission requests.
Type: float
Unit: count
admission_requested_sql_leaf_start_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_leaf_start_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_root_start Number of requests.
Type: float
Unit: count
admission_requested_sql_root_start_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_root_start_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_sql_response [OpenMetrics v1] Number of Distributed SQL admission requests.
Type: float
Unit: count
admission_requested_sql_sql_response_count [OpenMetrics v2] Number of Distributed SQL admission requests.
Type: float
Unit: count
admission_requested_sql_sql_response_locking_normal_pri Number of requests.
Type: float
Unit: count
admission_requested_sql_sql_response_normal_pri Number of requests.
Type: float
Unit: count
admission_scheduler_latency_listener_p99_nanos The scheduling latency at p99 as observed by the scheduler latency listener.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_bulk_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_bulk_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_bulk_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_elastic_cpu_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv [OpenMetrics v1] Wait time durations for KV requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_bucket [OpenMetrics v2] Wait time durations for KV requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_wait_durations_kv_count [OpenMetrics v2] Wait time durations for KV requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_high_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_high_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_high_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores [OpenMetrics v1] Wait time durations for KV stores requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_bucket [OpenMetrics v2] Wait time durations for KV stores requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_bulk_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_bulk_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_bulk_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_count [OpenMetrics v2] Wait time durations for KV stores requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_high_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_high_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_high_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_sum [OpenMetrics v2] Wait time durations for KV stores requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_ttl_low_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_ttl_low_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_stores_ttl_low_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_kv_sum [OpenMetrics v2] Wait time durations for KV requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response [OpenMetrics v1] Wait time durations for SQL KV response requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_bucket [OpenMetrics v2] Wait time durations for SQL KV response requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_count [OpenMetrics v2] Wait time durations for SQL KV response requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_kv_response_sum [OpenMetrics v2] Wait time durations for SQL KV response requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start [OpenMetrics v1] Wait time durations for SQL leaf start requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_bucket [OpenMetrics v2] Wait time durations for SQL leaf start requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_count [OpenMetrics v2] Wait time durations for SQL leaf start requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_leaf_start_sum [OpenMetrics v2] Wait time durations for SQL leaf start requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_root_start_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response [OpenMetrics v1] Wait time durations for Distributed SQL requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_bucket [OpenMetrics v2] Wait time durations for Distributed SQL requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_count [OpenMetrics v2] Wait time durations for Distributed SQL requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_locking_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_locking_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_locking_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_normal_pri_bucket Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_normal_pri_count Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_normal_pri_sum Wait time durations for requests that waited.
Type: float
Unit: time,ns
admission_wait_durations_sql_sql_response_sum [OpenMetrics v2] Wait time durations for Distributed SQL requests that waited.
Type: float
Unit: time,ns
admission_wait_queue_length_elastic_cpu Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_elastic_cpu_bulk_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_elastic_cpu_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv [OpenMetrics v1 & v2] Length of KV wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_bulk_normal_pri Number of requests admitted.
Type: float
Unit: count
admission_wait_queue_length_kv_high_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores [OpenMetrics v1 & v2] Length of KV stores wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores_bulk_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores_high_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_kv_stores_ttl_low_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_kv_response [OpenMetrics v1 & v2] Length of SQL KV wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_kv_response_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_kv_response_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_leaf_start [OpenMetrics v1 & v2] Length of SQL leaf start wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_leaf_start_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_leaf_start_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_root_start Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_root_start_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_root_start_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_sql_response [OpenMetrics v1 & v2] Length of Distributed SQL wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_sql_response_locking_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_length_sql_sql_response_normal_pri Length of wait queue.
Type: float
Unit: count
admission_wait_queue_lengths_sql_root_start [OpenMetrics v1 & v2] Length of SQL root start wait queue.
Type: float
Unit: count
admission_wait_sum_kv [OpenMetrics v1] Total KV wait time in micros.
Type: float
Unit: count
admission_wait_sum_kv_count [OpenMetrics v2] Total KV wait time in micros.
Type: float
Unit: count
admission_wait_sum_kv_stores [OpenMetrics v1] Total KV stores wait time in micros.
Type: float
Unit: count
admission_wait_sum_kv_stores_count [OpenMetrics v2] Total KV stores wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_kv_response [OpenMetrics v1] Total SQL KV wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_kv_response_count [OpenMetrics v2] Total SQL KV wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_root_start [OpenMetrics v1] Total SQL root start wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_root_start_count [OpenMetrics v2] Total SQL root start wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_sql_response [OpenMetrics v1] Total Distributed SQL wait time in micros.
Type: float
Unit: count
admission_wait_sum_sql_sql_response_count [OpenMetrics v2] Total Distributed SQL wait time in micros.
Type: float
Unit: count
backup_last_failed_time_kms_inaccessible The unix timestamp of the most recent failure of backup due to errKMSInaccessible by a backup specified as maintaining this metric.
Type: float
Unit: count
batch_requests_bytes Total byte count of batch requests processed.
Type: float
Unit: digital,B
batch_requests_cross_region_bytes Total byte count of batch requests processed cross region when region tiers are configured.
Type: float
Unit: digital,B
batch_requests_cross_zone_bytes Total 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.
Type: float
Unit: digital,B
batch_responses_bytes Total byte count of batch responses received.
Type: float
Unit: digital,B
batch_responses_cross_region_bytes Total byte count of batch responses received cross region when region tiers are configured.
Type: float
Unit: digital,B
batch_responses_cross_zone_bytes Total 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.
Type: float
Unit: digital,B
build_timestamp [OpenMetrics v1 & v2] Build information.
Type: float
Unit: count
capacity
Type: float
Unit: count
capacity_available [OpenMetrics v1 & v2] Available storage capacity.
Type: float
Unit: digital,B
capacity_reserved [OpenMetrics v1 & v2] Capacity reserved for snapshots.
Type: float
Unit: digital,B
capacity_total [OpenMetrics v1 & v2] Total storage capacity.
Type: float
Unit: digital,B
capacity_used [OpenMetrics v1 & v2] Used storage capacity.
Type: float
Unit: digital,B
changefeed_admit_latency [OpenMetrics v1] Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into change feed Pipeline.
Type: float
Unit: time,ns
changefeed_admit_latency_bucket [OpenMetrics v2] Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into change feed Pipeline.
Type: float
Unit: time,ns
changefeed_admit_latency_count [OpenMetrics v2] Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into change feed Pipeline.
Type: float
Unit: time,ns
changefeed_admit_latency_sum [OpenMetrics v2] Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into change feed Pipeline.
Type: float
Unit: time,ns
changefeed_aggregator_progress The earliest timestamp up to which any aggregator is guaranteed to have emitted all values for.
Type: float
Unit: count
changefeed_backfill [OpenMetrics v1 & v2] Number of change feeds currently executing backfill.
Type: float
Unit: count
changefeed_backfill_count Number of change feeds currently executing backfill.
Type: float
Unit: count
changefeed_backfill_pending_ranges [OpenMetrics v1 & v2] Number of ranges in an ongoing backfill that are yet to be fully emitted.
Type: float
Unit: count
changefeed_batch_reduction_count Number of times a change feed aggregator node attempted to reduce the size of message batches it emitted to the Sink.
Type: float
Unit: count
changefeed_buffer_entries_allocated_mem Current quota pool memory allocation.
Type: float
Unit: digital,B
changefeed_buffer_entries_flush Number of flush elements added to the buffer.
Type: float
Unit: count
changefeed_buffer_entries_in Total entries entering the buffer between raft and change feed sinks.
Type: float
Unit: count
changefeed_buffer_entries_kv Number of kv elements added to the buffer.
Type: float
Unit: count
changefeed_buffer_entries_mem_acquired Total amount of memory acquired for entries as they enter the system.
Type: float
Unit: count
changefeed_buffer_entries_mem_released Total amount of memory released by the entries after they have been emitted.
Type: float
Unit: count
changefeed_buffer_entries_out Total entries leaving the buffer between raft and change feed sinks.
Type: float
Unit: count
changefeed_buffer_entries_released Total entries processed, emitted and acknowledged by the sinks.
Type: float
Unit: count
changefeed_buffer_entries_resolved Number of resolved elements added to the buffer.
Type: float
Unit: count
changefeed_buffer_pushback Total time spent waiting while the buffer was full.
Type: float
Unit: time,ns
changefeed_bytes_messages_pushback Total time spent throttled for bytes quota.
Type: float
Unit: time,ns
changefeed_checkpoint_hist_nanos_bucket Time spent check pointing change feed progress.
Type: float
Unit: time,ns
changefeed_checkpoint_hist_nanos_count Time spent check pointing change feed progress.
Type: float
Unit: time,ns
changefeed_checkpoint_hist_nanos_sum Time spent check pointing change feed progress.
Type: float
Unit: time,ns
changefeed_checkpoint_progress The earliest timestamp of any change feed's persisted checkpoint (values prior to this timestamp will never need to be re-emitted).
Type: float
Unit: count
changefeed_cloudstorage_buffered_bytes The number of bytes buffered in cloud storage Sink files which have not been emitted yet.
Type: float
Unit: count
changefeed_commit_latency [OpenMetrics v1] Event commit latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was acknowledged by the downstream Sink.
Type: float
Unit: time,ns
changefeed_commit_latency_bucket [OpenMetrics v2] Event commit latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was acknowledged by the downstream Sink.
Type: float
Unit: time,ns
changefeed_commit_latency_count [OpenMetrics v2] Event commit latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was acknowledged by the downstream Sink.
Type: float
Unit: time,ns
changefeed_commit_latency_sum [OpenMetrics v2] Event commit latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was acknowledged by the downstream Sink.
Type: float
Unit: time,ns
changefeed_emitted_bytes Bytes emitted by all feeds.
Type: float
Unit: digital,B
changefeed_emitted_bytes_count Bytes emitted by all feeds.
Type: float
Unit: count
changefeed_emitted_messages [OpenMetrics v1] Messages emitted by all feeds.
Type: float
Unit: count
changefeed_emitted_messages_count [OpenMetrics v2] Messages emitted by all feeds.
Type: float
Unit: count
changefeed_error_retries [OpenMetrics v1] Total retry able errors encountered by all change feeds.
Type: float
Unit: count
changefeed_error_retries_count [OpenMetrics v2] Total retry able errors encountered by all change feeds.
Type: float
Unit: count
changefeed_failures [OpenMetrics v1] Total number of change feed jobs which have failed.
Type: float
Unit: count
changefeed_failures_count [OpenMetrics v2] Total number of change feed jobs which have failed.
Type: float
Unit: count
changefeed_filtered_messages Messages filtered out by all feeds. This count does not include the number of messages that may be filtered due to the range constraints.
Type: float
Unit: count
changefeed_flush_hist_nanos_bucket Time spent flushing messages across all change feeds.
Type: float
Unit: time,ns
changefeed_flush_hist_nanos_count Time spent flushing messages across all change feeds.
Type: float
Unit: time,ns
changefeed_flush_hist_nanos_sum Time spent flushing messages across all change feeds.
Type: float
Unit: time,ns
changefeed_flush_messages_pushback Total time spent throttled for flush quota.
Type: float
Unit: time,ns
changefeed_flushed_bytes Bytes emitted by all feeds; maybe different from changefeed.emitted_bytes when compression is enabled.
Type: float
Unit: digital,B
changefeed_flushes Total flushes across all feeds.
Type: float
Unit: count
changefeed_forwarded_resolved_messages Resolved timestamps forwarded from the change aggregator to the change frontier.
Type: float
Unit: count
changefeed_frontier_updates Number of change frontier updates across all feeds.
Type: float
Unit: count
changefeed_internal_retry_message_count Number of messages for which an attempt to retry them within an aggregator node was made.
Type: float
Unit: count
changefeed_lagging_ranges The number of ranges considered to be lagging behind.
Type: float
Unit: count
changefeed_max_behind_nanos [OpenMetrics v1 & v2] Largest commit-to-emit duration of any running feed.
Type: float
Unit: count
changefeed_message_size_hist [OpenMetrics v1] Message size histogram.
Type: float
Unit: count
changefeed_message_size_hist_bucket [OpenMetrics v2] Message size histogram.
Type: float
Unit: count
changefeed_message_size_hist_count [OpenMetrics v2] Message size histogram.
Type: float
Unit: count
changefeed_message_size_hist_sum [OpenMetrics v2] Message size histogram.
Type: float
Unit: count
changefeed_messages_messages_pushback Total time spent throttled for messages quota.
Type: float
Unit: time,ns
changefeed_nprocs_consume_event_nanos_bucket Total time spent waiting to add an event to the parallel consumer.
Type: float
Unit: time,ns
changefeed_nprocs_consume_event_nanos_count Total time spent waiting to add an event to the parallel consumer.
Type: float
Unit: time,ns
changefeed_nprocs_consume_event_nanos_sum Total time spent waiting to add an event to the parallel consumer.
Type: float
Unit: time,ns
changefeed_nprocs_flush_nanos_bucket Total time spent idle waiting for the parallel consumer to flush.
Type: float
Unit: time,ns
changefeed_nprocs_flush_nanos_count Total time spent idle waiting for the parallel consumer to flush.
Type: float
Unit: time,ns
changefeed_nprocs_flush_nanos_sum Total time spent idle waiting for the parallel consumer to flush.
Type: float
Unit: time,ns
changefeed_nprocs_in_flight_count Number of buffered events in the parallel consumer.
Type: float
Unit: count
changefeed_parallel_io_queue_nanos_bucket Time spent with outgoing requests to the Sink waiting in queue due to inflight requests with conflicting keys.
Type: float
Unit: time,ns
changefeed_parallel_io_queue_nanos_count Time spent with outgoing requests to the Sink waiting in queue due to inflight requests with conflicting keys.
Type: float
Unit: time,ns
changefeed_parallel_io_queue_nanos_sum Time spent with outgoing requests to the Sink waiting in queue due to inflight requests with conflicting keys.
Type: float
Unit: time,ns
changefeed_queue_time Time KV event spent waiting to be processed.
Type: float
Unit: time,ns
changefeed_replan_count
Type: float
Unit: count
changefeed_running [OpenMetrics v1 & v2] Number of currently running change feeds, including Sink less.
Type: float
Unit: count
changefeed_schema_registry_registrations Number of registration attempts with the schema registry.
Type: float
Unit: count
changefeed_schema_registry_retry_count Number of retries encountered when sending requests to the schema registry.
Type: float
Unit: count
changefeed_schemafeed_table_history_scans The number of table history scans during polling.
Type: float
Unit: count
changefeed_schemafeed_table_metadata Time blocked while verifying table metadata histories.
Type: float
Unit: time,ns
changefeed_sink_batch_hist_nanos_bucket Time spent batched in the Sink buffer before being flushed and acknowledged.
Type: float
Unit: time,ns
changefeed_sink_batch_hist_nanos_count Time spent batched in the Sink buffer before being flushed and acknowledged.
Type: float
Unit: time,ns
changefeed_sink_batch_hist_nanos_sum Time spent batched in the Sink buffer before being flushed and acknowledged.
Type: float
Unit: time,ns
changefeed_sink_io_inflight The number of keys currently inflight as IO requests being sent to the Sink.
Type: float
Unit: count
changefeed_size_based_flushes Total size based flushes across all feeds.
Type: float
Unit: count
clock_offset_meannanos [OpenMetrics v1 & v2] Mean clock offset with other nodes in nanoseconds.
Type: float
Unit: time,ns
clock_offset_stddevnanos [OpenMetrics v1 & v2] Standard Deviation clock offset with other nodes in nanoseconds.
Type: float
Unit: time,ns
cloud_read_bytes Number of bytes read.
Type: float
Unit: digital,B
cloud_write_bytes Number of bytes read.
Type: float
Unit: digital,B
cluster_preserve_downgrade_option_last_updated Timestamp of the last time the preserve down grade option was updated.
Type: float
Unit: count
compactor_compactingnanos [OpenMetrics v1] Number of nanoseconds spent compacting ranges.
Type: float
Unit: time,ns
compactor_compactingnanos_count [OpenMetrics v2] Number of nanoseconds spent compacting ranges.
Type: float
Unit: time,ns
compactor_compactions_failure [OpenMetrics v1] Number of failed compaction requests sent to the storage engine.
Type: float
Unit: count
compactor_compactions_failure_count [OpenMetrics v2] Number of failed compaction requests sent to the storage engine.
Type: float
Unit: count
compactor_compactions_success [OpenMetrics v1] Number of successful compaction requests sent to the storage engine.
Type: float
Unit: count
compactor_compactions_success_count [OpenMetrics v2] Number of successful compaction requests sent to the storage engine.
Type: float
Unit: count
compactor_suggestionbytes_compacted [OpenMetrics v1] Number of logical bytes compacted from suggested compactions.
Type: float
Unit: digital,B
compactor_suggestionbytes_compacted_count [OpenMetrics v2] Number of logical bytes compacted from suggested compactions.
Type: float
Unit: digital,B
compactor_suggestionbytes_queued [OpenMetrics v1 & v2] Number of logical bytes in suggested compactions in the queue.
Type: float
Unit: digital,B
compactor_suggestionbytes_skipped [OpenMetrics v1] Number of logical bytes in suggested compactions which were not compacted.
Type: float
Unit: digital,B
compactor_suggestionbytes_skipped_count [OpenMetrics v2] Number of logical bytes in suggested compactions which were not compacted.
Type: float
Unit: digital,B
distsender_batch_requests_cross_region_bytes Total byte count of replica-addressed batch requests processed cross region when region tiers are configured.
Type: float
Unit: digital,B
distsender_batch_requests_cross_zone_bytes Total 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.
Type: float
Unit: digital,B
distsender_batch_requests_replica_addressed_bytes Total byte count of replica-addressed batch requests processed.
Type: float
Unit: digital,B
distsender_batch_responses_cross_region_bytes Total byte count of replica-addressed batch responses received cross region when region tiers are configured.
Type: float
Unit: digital,B
distsender_batch_responses_cross_zone_bytes Total 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.
Type: float
Unit: digital,B
distsender_batch_responses_replica_addressed_bytes Total byte count of replica-addressed batch responses received.
Type: float
Unit: digital,B
distsender_batches Number of batches processed.
Type: float
Unit: count
distsender_batches_async_sent Number of partial batches sent asynchronously.
Type: float
Unit: count
distsender_batches_async_throttled Number of partial batches not sent asynchronously due to throttling.
Type: float
Unit: count
distsender_batches_partial [OpenMetrics v1] Number of partial batches processed.
Type: float
Unit: count
distsender_batches_partial_count [OpenMetrics v2] Number of partial batches processed.
Type: float
Unit: count
distsender_batches_total [OpenMetrics v1] Number of batches processed.
Type: float
Unit: count
distsender_batches_total_count [OpenMetrics v2] Number of batches processed.
Type: float
Unit: count
distsender_errors_inleasetransferbackoffs Number of times backed off due to NotLeaseHolderErrors during lease transfer.
Type: float
Unit: count
distsender_errors_notleaseholder [OpenMetrics v1] Number of NotLeaseHolderErrors encountered.
Type: float
Unit: count
distsender_errors_notleaseholder_count [OpenMetrics v2] Number of NotLeaseHolderErrors encountered.
Type: float
Unit: count
distsender_rangefeed_catchup_ranges Number of ranges in catchup modeThis counts the number of ranges with an active range feed that are performing catchup scan.
Type: float
Unit: count
distsender_rangefeed_error_catchup_ranges Number of ranges in catchup mode which experienced an error.
Type: float
Unit: count
distsender_rangefeed_restart_ranges Number of ranges that were restarted due to transient errors.
Type: float
Unit: count
distsender_rangefeed_retry_logical_ops_missing Number of ranges that encountered retry able LOGICAL OPS MISSING error.
Type: float
Unit: count
distsender_rangefeed_retry_no_leaseholder Number of ranges that encountered retry able NO_LEASEHOLDER error.
Type: float
Unit: count
distsender_rangefeed_retry_node_not_found Number of ranges that encountered retry able node not found error.
Type: float
Unit: count
distsender_rangefeed_retry_raft_snapshot Number of ranges that encountered retry able RAFT_SNAPSHOT error.
Type: float
Unit: count
distsender_rangefeed_retry_range_key_mismatch Number of ranges that encountered retry able range key mismatch error.
Type: float
Unit: count
distsender_rangefeed_retry_range_merged Number of ranges that encountered retry able RANGE_MERGED error.
Type: float
Unit: count
distsender_rangefeed_retry_range_not_found Number of ranges that encountered retry able range not found error.
Type: float
Unit: count
distsender_rangefeed_retry_range_split Number of ranges that encountered retry able RANGE_SPLIT error.
Type: float
Unit: count
distsender_rangefeed_retry_rangefeed_closed Number of ranges that encountered retry able RANGEFEED_CLOSED error.
Type: float
Unit: count
distsender_rangefeed_retry_replica_removed Number of ranges that encountered retry able REPLICA_REMOVED error.
Type: float
Unit: count
distsender_rangefeed_retry_send Number of ranges that encountered retry able send error.
Type: float
Unit: count
distsender_rangefeed_retry_slow_consumer Number of ranges that encountered retry able SLOW_CONSUMER error.
Type: float
Unit: count
distsender_rangefeed_retry_store_not_found Number of ranges that encountered retry able store not found error.
Type: float
Unit: count
distsender_rangefeed_retry_stuck Number of ranges that encountered retry able stuck error.
Type: float
Unit: count
distsender_rangefeed_total_ranges Number of ranges executing range feed This counts the number of ranges with an active range feed.
Type: float
Unit: count
distsender_rangelookups Number of range lookups.
Type: float
Unit: count
distsender_rpc_addsstable_sent Number of AddSSTable requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminchangereplicas_sent Number of AdminChangeReplicas requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminmerge_sent Number of AdminMerge requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminrelocaterange_sent Number of AdminRelocateRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminscatter_sent Number of AdminScatter requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminsplit_sent Number of AdminSplit requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_admintransferlease_sent Number of AdminTransferLease requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminunsplit_sent Number of Admin un split requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_adminverifyprotectedtimestamp_sent Number of AdminVerifyProtectedTimestamp requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_barrier_sent Number of Barrier requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_checkconsistency_sent Number of CheckConsistency requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_clearrange_sent Number of ClearRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_computechecksum_sent Number of ComputeChecksum requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_conditionalput_sent Number of ConditionalPut requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_delete_sent Number of Delete requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_deleterange_sent Number of DeleteRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_endtxn_sent Number of EndTxn requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_err_ambiguousresulterrtype Number of AmbiguousResultErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_batchtimestampbeforegcerrtype Number of BatchTimestampBeforeGCErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_communicationerrtype Number of CommunicationErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_conditionfailederrtype Number of ConditionFailedErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_errordetailtype Number of ErrorDetailType (tagged by their number) errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_indeterminatecommiterrtype Number of IndeterminateCommitErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_integeroverflowerrtype Number of IntegerOverflowErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_intentmissingerrtype Number of IntentMissingErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_internalerrtype Number of InternalErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_invalidleaseerrtype Number of InvalidLeaseErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_leaserejectederrtype Number of LeaseRejectedErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_lockconflicterrtype Number of LockConflictErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_mergeinprogresserrtype Number of MergeInProgressErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_mintimestampboundunsatisfiableerrtype Number of MinTimestampBoundUnsatisfiableErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_mvcchistorymutationerrtype Number of MVCCHistoryMutationErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_nodeunavailableerrtype Number of NodeUnavailableErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_notleaseholdererrtype Number of NotLeaseHolderErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_oprequirestxnerrtype Number of OpRequiresTxnErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_optimisticevalconflictserrtype Number of OptimisticEvalConflictsErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_raftgroupdeletederrtype Number of RaftGroupDeletedErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_rangefeedretryerrtype Number of RangeFeedRetryErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_rangekeymismatcherrtype Number of RangeKeyMismatchErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_rangenotfounderrtype Number of RangeNotFoundErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_readwithinuncertaintyintervalerrtype Number of ReadWithinUncertaintyIntervalErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_refreshfailederrtype Number of RefreshFailedErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_replicacorruptionerrtype Number of ReplicaCorruptionErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_replicatooolderrtype Number of ReplicaTooOldErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_storenotfounderrtype Number of StoreNotFoundErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_transactionabortederrtype Number of TransactionAbortedErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_transactionpusherrtype Number of TransactionPushErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_transactionretryerrtype Number of TransactionRetryErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_transactionretrywithprotorefresherrtype Number of TransactionRetryWithProtoRefreshErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_transactionstatuserrtype Number of TransactionStatusErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_txnalreadyencounterederrtype Number of TxnAlreadyEncounteredErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_unsupportedrequesterrtype Number of UnsupportedRequestErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_writeintenterrtype Number of WriteIntentErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_err_writetooolderrtype Number of WriteTooOldErrType errors received replica-bound RPCsThis 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 unclassifiederrors as 'roachpb.InternalErrType'.
Type: float
Unit: count
distsender_rpc_export_sent Number of Export requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_gc_sent Number of GC requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_get_sent Number of Get requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_heartbeattxn_sent Number of HeartbeatTxn requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_increment_sent Number of Increment requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_initput_sent Number of InitPut requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_isspanempty_sent Number of IsSpanEmpty requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_leaseinfo_sent Number of LeaseInfo requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_merge_sent Number of Merge requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_migrate_sent Number of Migrate requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_probe_sent Number of Probe requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_pushtxn_sent Number of PushTxn requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_put_sent Number of Put requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_queryintent_sent Number of QueryIntent requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_querylocks_sent Number of QueryLocks requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_queryresolvedtimestamp_sent Number of QueryResolvedTimestamp requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_querytxn_sent Number of QueryTxn requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_rangestats_sent Number of RangeStats requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_recomputestats_sent Number of RecomputeStats requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_recovertxn_sent Number of RecoverTxn requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_refresh_sent Number of Refresh requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_refreshrange_sent Number of RefreshRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_requestlease_sent Number of RequestLease requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_resolveintent_sent Number of ResolveIntent requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_resolveintentrange_sent Number of ResolveIntentRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_reversescan_sent Number of ReverseScan requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_revertrange_sent Number of RevertRange requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_scan_sent Number of Scan requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_sent Number of replica-addressed RPCs sent.
Type: float
Unit: count
distsender_rpc_sent_local [OpenMetrics v1] Number of local RPCs sent.
Type: float
Unit: count
distsender_rpc_sent_local_count [OpenMetrics v2] Number of local RPCs sent.
Type: float
Unit: count
distsender_rpc_sent_nextreplicaerror [OpenMetrics v1] Number of RPCs sent due to per-replica errors.
Type: float
Unit: count
distsender_rpc_sent_nextreplicaerror_count [OpenMetrics v2] Number of RPCs sent due to per-replica errors.
Type: float
Unit: count
distsender_rpc_sent_total [OpenMetrics v1] Number of RPCs sent.
Type: float
Unit: count
distsender_rpc_sent_total_count [OpenMetrics v2] Number of replica-addressed RPCs sent.
Type: float
Unit: count
distsender_rpc_subsume_sent Number of Subsume requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_transferlease_sent Number of TransferLease requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_truncatelog_sent Number of TruncateLog requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
distsender_rpc_writebatch_sent Number of WriteBatch requests processed.This counts the requests in batches handed to DistSender, not the RPCs sent to individual Ranges as a result.
Type: float
Unit: count
exec_error [OpenMetrics v1] Number of batch KV requests that failed to execute on this node. These are warnings denoting cleanup rather than errors, and can be disregarded as part of operation.
Type: float
Unit: count
exec_error_count [OpenMetrics v2] Number of batch KV requests that failed to execute on this node. These are warnings denoting cleanup rather than errors, and can be disregarded as part of operation.
Type: float
Unit: count
exec_latency [OpenMetrics v1] Latency in nanoseconds of batch KV requests executed on this node.
Type: float
Unit: time,ns
exec_latency_bucket [OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node.
Type: float
Unit: time,ns
exec_latency_count [OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node.
Type: float
Unit: time,ns
exec_latency_sum [OpenMetrics v2] Latency in nanoseconds of batch KV requests executed on this node.
Type: float
Unit: time,ns
exec_success [OpenMetrics v1] Number of batch KV requests executed successfully on this node.
Type: float
Unit: count
exec_success_count [OpenMetrics v2] Number of batch KV requests executed successfully on this node.
Type: float
Unit: count
exportrequest_delay_count Number of Export requests delayed due to concurrent requests.
Type: float
Unit: count
follower_reads_success_count Number of successful follower reads.
Type: float
Unit: count
gcbytesage [OpenMetrics v1 & v2] Cumulative age of non-live data in seconds.
Type: float
Unit: time,s
gossip_bytes_received [OpenMetrics v1] Number of received gossip bytes.
Type: float
Unit: digital,B
gossip_bytes_received_count [OpenMetrics v2] Number of received gossip bytes.
Type: float
Unit: digital,B
gossip_bytes_sent [OpenMetrics v1] Number of sent gossip bytes.
Type: float
Unit: digital,B
gossip_bytes_sent_count [OpenMetrics v2] Number of sent gossip bytes.
Type: float
Unit: digital,B
gossip_connections_incoming [OpenMetrics v1 & v2] Number of active incoming gossip connections.
Type: float
Unit: count
gossip_connections_outgoing [OpenMetrics v1 & v2] Number of active outgoing gossip connections.
Type: float
Unit: count
gossip_connections_refused [OpenMetrics v1] Number of refused incoming gossip connections.
Type: float
Unit: count
gossip_connections_refused_count [OpenMetrics v2] Number of refused incoming gossip connections.
Type: float
Unit: count
gossip_infos_received [OpenMetrics v1] Number of received gossip Info objects.
Type: float
Unit: count
gossip_infos_received_count [OpenMetrics v2] Number of received gossip Info objects.
Type: float
Unit: count
gossip_infos_sent [OpenMetrics v1] Number of sent gossip Info objects.
Type: float
Unit: count
gossip_infos_sent_count [OpenMetrics v2] Number of sent gossip Info objects.
Type: float
Unit: count
intentage [OpenMetrics v1 & v2] Cumulative age of intents in seconds.
Type: float
Unit: time,s
intentbytes [OpenMetrics v1 & v2] Number of bytes in intent KV pairs.
Type: float
Unit: digital,B
intentcount [OpenMetrics v1 & v2] Count of intent keys.
Type: float
Unit: count
intentresolver_async_throttled Number of intent resolution attempts not run asynchronously due to throttling.
Type: float
Unit: count
intentresolver_async_throttled_count Number of intent resolution attempts not run asynchronously due to throttling.
Type: float
Unit: count
intentresolver_finalized_txns_failed Number 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.
Type: float
Unit: count
intentresolver_finalized_txns_failed_count Number 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.
Type: float
Unit: count
intentresolver_intents_failed Number 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.
Type: float
Unit: count
intentresolver_intents_failed_count Number 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.
Type: float
Unit: count
intents_abort_attempts Count of (point or range) non-poisoning intent abort evaluation attempts.
Type: float
Unit: count
intents_abort_attempts_count Count of (point or range) non-poisoning intent abort evaluation attempts.
Type: float
Unit: count
intents_poison_attempts Count of (point or range) poisoning intent abort evaluation attempts.
Type: float
Unit: count
intents_poison_attempts_count Count of (point or range) poisoning intent abort evaluation attempts.
Type: float
Unit: count
intents_resolve_attempts Count of (point or range) intent commit evaluation attempts.
Type: float
Unit: count
intents_resolve_attempts_count Count of (point or range) intent commit evaluation attempts.
Type: float
Unit: count
jobs.auto_sql_stats_compaction.protected_record_count
Type: float
Unit: count
jobs_adopt_iterations number of job-adopt iterations performed by the registry.
Type: float
Unit: count
jobs_auto_config_env_runner_currently_idle Number of autoconfigenv_runner jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_config_env_runner_currently_paused Number of autoconfigenv_runner jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_config_env_runner_currently_running Number of autoconfigenv_runner jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_config_env_runner_expired_pts_records Number of expired protected timestamp records owned by autoconfigenv_runner jobs.
Type: float
Unit: count
jobs_auto_config_env_runner_fail_or_cancel_completed Number of autoconfigenv_runner jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_env_runner_fail_or_cancel_failed Number of autoconfigenv_runner jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_env_runner_fail_or_cancel_retry_error Number of autoconfigenv_runner jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_env_runner_protected_age_sec The age of the oldest PTS record protected by autoconfigenv_runner jobs.
Type: float
Unit: time,s
jobs_auto_config_env_runner_protected_record Number of protected timestamp records held by autoconfigenv_runner jobs.
Type: float
Unit: count
jobs_auto_config_env_runner_resume_completed Number of autoconfigenv_runner jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_config_env_runner_resume_failed Number of autoconfigenv_runner jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_config_env_runner_resume_retry_error Number of autoconfigenv_runner jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_config_runner_currently_idle Number of auto config runner jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_config_runner_currently_paused Number of auto config runner jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_config_runner_currently_running Number of auto config runner jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_config_runner_expired_pts_records Number of expired protected timestamp records owned by auto config runner jobs.
Type: float
Unit: count
jobs_auto_config_runner_fail_or_cancel_completed Number of auto config runner jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_runner_fail_or_cancel_failed Number of auto config runner jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_runner_fail_or_cancel_retry_error Number of auto config runner jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_runner_protected_age_sec The age of the oldest PTS record protected by auto config runner jobs.
Type: float
Unit: time,s
jobs_auto_config_runner_protected_record Number of protected timestamp records held by auto config runner jobs.
Type: float
Unit: count
jobs_auto_config_runner_resume_completed Number of auto config runner jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_config_runner_resume_failed Number of auto config runner jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_config_runner_resume_retry_error Number of auto config runner jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_config_task_currently_idle Number of auto_config_task jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_config_task_currently_paused Number of auto_config_task jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_config_task_currently_running Number of auto_config_task jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_config_task_expired_pts_records Number of expired protected timestamp records owned by auto_config_task jobs.
Type: float
Unit: count
jobs_auto_config_task_fail_or_cancel_completed Number of auto_config_task jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_task_fail_or_cancel_failed Number of auto_config_task jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_task_fail_or_cancel_retry_error Number of auto_config_task jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_config_task_protected_age_sec The age of the oldest PTS record protected by auto_config_task jobs.
Type: float
Unit: time,s
jobs_auto_config_task_protected_record Number of protected timestamp records held by auto_config_task jobs.
Type: float
Unit: count
jobs_auto_config_task_resume_completed Number of auto_config_task jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_config_task_resume_failed Number of auto_config_task jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_config_task_resume_retry_error Number of auto_config_task jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_create_stats_currently_idle Number of auto_create_stats jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_create_stats_currently_paused Number of auto_create_stats jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_create_stats_currently_running Number of auto_create_stats jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_create_stats_expired_pts_records Number of expired protected timestamp records owned by auto_create_stats jobs.
Type: float
Unit: count
jobs_auto_create_stats_fail_or_cancel_completed Number of auto_create_stats jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_create_stats_fail_or_cancel_failed Number of auto_create_stats jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_create_stats_fail_or_cancel_retry_error Number of auto_create_stats jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_create_stats_protected_age_sec The age of the oldest PTS record protected by auto_create_stats jobs.
Type: float
Unit: time,s
jobs_auto_create_stats_protected_record Number of protected timestamp records held by auto_create_stats jobs.
Type: float
Unit: count
jobs_auto_create_stats_resume_completed Number of auto_create_stats jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_create_stats_resume_failed Number of auto_create_stats jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_create_stats_resume_retry_error Number of auto_create_stats jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_schema_telemetry_currently_idle Number of auto_schema_telemetry jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_schema_telemetry_currently_paused Number of auto_schema_telemetry jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_schema_telemetry_currently_running Number of auto_schema_telemetry jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_schema_telemetry_expired_pts_records Number of expired protected timestamp records owned by auto_schema_telemetry jobs.
Type: float
Unit: count
jobs_auto_schema_telemetry_fail_or_cancel_completed Number of auto_schema_telemetry jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_schema_telemetry_fail_or_cancel_failed Number of auto_schema_telemetry jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_schema_telemetry_fail_or_cancel_retry_error Number of auto_schema_telemetry jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_schema_telemetry_protected_age_sec The age of the oldest PTS record protected by auto_schema_telemetry jobs.
Type: float
Unit: time,s
jobs_auto_schema_telemetry_protected_record Number of protected timestamp records held by auto_schema_telemetry jobs.
Type: float
Unit: count
jobs_auto_schema_telemetry_resume_completed Number of auto_schema_telemetry jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_schema_telemetry_resume_failed Number of auto_schema_telemetry jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_schema_telemetry_resume_retry_error Number of auto_schema_telemetry jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_currently_idle Number of autospanconfig_reconciliation jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_currently_paused Number of autospanconfig_reconciliation jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_currently_running Number of autospanconfig_reconciliation jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_expired_pts_records Number of expired protected timestamp records owned by autospanconfig_reconciliation jobs.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_fail_or_cancel_completed Number of autospanconfig_reconciliation jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_fail_or_cancel_failed Number of autospanconfig_reconciliation jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_fail_or_cancel_retry_error Number of autospanconfig_reconciliation jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_protected_age_sec The age of the oldest PTS record protected by autospanconfig_reconciliation jobs.
Type: float
Unit: time,s
jobs_auto_span_config_reconciliation_protected_record Number of protected timestamp records held by autospanconfig_reconciliation jobs.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_resume_completed Number of autospanconfig_reconciliation jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_resume_failed Number of autospanconfig_reconciliation jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_span_config_reconciliation_resume_retry_error Number of autospanconfig_reconciliation jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_currently_idle Number of autosqlstats_compaction jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_currently_paused Number of autosqlstats_compaction jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_currently_running Number of autosqlstats_compaction jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_expired_pts_records Number of expired protected timestamp records owned by autosqlstats_compaction jobs.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_fail_or_cancel_completed Number of autosqlstats_compaction jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_fail_or_cancel_failed Number of autosqlstats_compaction jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_fail_or_cancel_retry_error Number of autosqlstats_compaction jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_protected_age_sec The age of the oldest PTS record protected by autosqlstats_compaction jobs.
Type: float
Unit: time,s
jobs_auto_sql_stats_compaction_protected_record Number of protected timestamp records held by autosqlstats_compaction jobs.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_protected_record_count
Type: float
Unit: count
jobs_auto_sql_stats_compaction_resume_completed Number of autosqlstats_compaction jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_resume_failed Number of autosqlstats_compaction jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_sql_stats_compaction_resume_retry_error Number of autosqlstats_compaction jobs which failed with a retry able error.
Type: float
Unit: count
jobs_auto_update_sql_activity_currently_idle Number of autoupdatesql_activity jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_auto_update_sql_activity_currently_paused Number of autoupdatesql_activity jobs currently considered Paused.
Type: float
Unit: count
jobs_auto_update_sql_activity_currently_running Number of autoupdatesql_activity jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_auto_update_sql_activity_expired_pts_records Number of expired protected timestamp records owned by autoupdatesql_activity jobs.
Type: float
Unit: count
jobs_auto_update_sql_activity_fail_or_cancel_completed Number of autoupdatesql_activity jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_auto_update_sql_activity_fail_or_cancel_failed Number of autoupdatesql_activity jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_update_sql_activity_fail_or_cancel_retry_error Number of autoupdatesql_activity jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_auto_update_sql_activity_protected_age_sec The age of the oldest PTS record protected by autoupdatesql_activity jobs.
Type: float
Unit: time,s
jobs_auto_update_sql_activity_protected_record Number of protected timestamp records held by autoupdatesql_activity jobs.
Type: float
Unit: count
jobs_auto_update_sql_activity_resume_completed Number of autoupdatesql_activity jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_auto_update_sql_activity_resume_failed Number of autoupdatesql_activity jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_auto_update_sql_activity_resume_retry_error Number of autoupdatesql_activity jobs which failed with a retry able error.
Type: float
Unit: count
jobs_backup_currently_idle [OpenMetrics v1 & v2] Number of backup jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_backup_currently_paused Number of backup jobs currently considered Paused.
Type: float
Unit: count
jobs_backup_currently_running [OpenMetrics v1 & v2] Number of backup jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_backup_expired_pts_records Number of expired protected timestamp records owned by backup jobs.
Type: float
Unit: count
jobs_backup_fail_or_cancel_completed Number of backup jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_backup_fail_or_cancel_failed [OpenMetrics v1] Number of backup jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_backup_fail_or_cancel_failed_count [OpenMetrics v2] Number of backup jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_backup_fail_or_cancel_retry_error [OpenMetrics v1] Number of backup jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_backup_fail_or_cancel_retry_error_count [OpenMetrics v2] Number of backup jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_backup_protected_age_sec The age of the oldest PTS record protected by backup jobs.
Type: float
Unit: time,s
jobs_backup_protected_record Number of protected timestamp records held by backup jobs.
Type: float
Unit: count
jobs_backup_resume_completed Number of backup jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_backup_resume_failed [OpenMetrics v1] Number of backup jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_backup_resume_failed_count [OpenMetrics v2] Number of backup jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_backup_resume_retry_error [OpenMetrics v1] Number of backup jobs which failed with a retry able error.
Type: float
Unit: count
jobs_backup_resume_retry_error_count [OpenMetrics v2] Number of backup jobs which failed with a retry able error.
Type: float
Unit: count
jobs_changefeed_currently_idle Number of change feed jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_changefeed_currently_paused Number of change feed jobs currently considered Paused.
Type: float
Unit: count
jobs_changefeed_currently_running Number of change feed jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_changefeed_expired_pts_records Number of expired protected timestamp records owned by change feed jobs.
Type: float
Unit: count
jobs_changefeed_fail_or_cancel_completed Number of change feed jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_changefeed_fail_or_cancel_failed Number of change feed jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_changefeed_fail_or_cancel_retry_error Number of change feed jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_changefeed_protected_age_sec The age of the oldest PTS record protected by change feed jobs.
Type: float
Unit: time,s
jobs_changefeed_protected_record Number of protected timestamp records held by change feed jobs.
Type: float
Unit: count
jobs_changefeed_resume_completed Number of change feed jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_changefeed_resume_failed Number of change feed jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_changefeed_resume_retry_error [OpenMetrics v1] Number of change feed jobs which failed with a retry able error.
Type: float
Unit: count
jobs_changefeed_resume_retry_error_count [OpenMetrics v2] Number of change feed jobs which failed with a retry able error.
Type: float
Unit: count
jobs_claimed_jobs number of jobs claimed in job-adopt iterations.
Type: float
Unit: count
jobs_create_stats_currently_idle Number of create_stats jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_create_stats_currently_paused Number of create_stats jobs currently considered Paused.
Type: float
Unit: count
jobs_create_stats_currently_running Number of create_stats jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_create_stats_expired_pts_records Number of expired protected timestamp records owned by create_stats jobs.
Type: float
Unit: count
jobs_create_stats_fail_or_cancel_completed Number of create_stats jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_create_stats_fail_or_cancel_failed Number of create_stats jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_create_stats_fail_or_cancel_retry_error Number of create_stats jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_create_stats_protected_age_sec The age of the oldest PTS record protected by create_stats jobs.
Type: float
Unit: time,s
jobs_create_stats_protected_record Number of protected timestamp records held by create_stats jobs.
Type: float
Unit: count
jobs_create_stats_resume_completed Number of create_stats jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_create_stats_resume_failed Number of create_stats jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_create_stats_resume_retry_error Number of create_stats jobs which failed with a retry able error.
Type: float
Unit: count
jobs_import_currently_idle Number of import jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_import_currently_paused Number of import jobs currently considered Paused.
Type: float
Unit: count
jobs_import_currently_running Number of import jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_import_expired_pts_records Number of expired protected timestamp records owned by import jobs.
Type: float
Unit: count
jobs_import_fail_or_cancel_completed Number of import jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_import_fail_or_cancel_failed Number of import jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_import_fail_or_cancel_retry_error Number of import jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_import_protected_age_sec The age of the oldest PTS record protected by import jobs.
Type: float
Unit: time,s
jobs_import_protected_record Number of protected timestamp records held by import jobs.
Type: float
Unit: count
jobs_import_resume_completed Number of import jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_import_resume_failed Number of import jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_import_resume_retry_error Number of import jobs which failed with a retry able error.
Type: float
Unit: count
jobs_key_visualizer_currently_idle Number of key_visualizer jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_key_visualizer_currently_paused Number of key_visualizer jobs currently considered Paused.
Type: float
Unit: count
jobs_key_visualizer_currently_running Number of key_visualizer jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_key_visualizer_expired_pts_records Number of expired protected timestamp records owned by key_visualizer jobs.
Type: float
Unit: count
jobs_key_visualizer_fail_or_cancel_completed Number of key_visualizer jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_key_visualizer_fail_or_cancel_failed Number of key_visualizer jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_key_visualizer_fail_or_cancel_retry_error Number of key_visualizer jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_key_visualizer_protected_age_sec The age of the oldest PTS record protected by key_visualizer jobs.
Type: float
Unit: time,s
jobs_key_visualizer_protected_record Number of protected timestamp records held by key_visualizer jobs.
Type: float
Unit: count
jobs_key_visualizer_resume_completed Number of key_visualizer jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_key_visualizer_resume_failed Number of key_visualizer jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_key_visualizer_resume_retry_error Number of key_visualizer jobs which failed with a retry able error.
Type: float
Unit: count
jobs_metrics_task_failed Number of metrics SQL activity updater tasks that failed.
Type: float
Unit: count
jobs_migration_currently_idle Number of migration jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_migration_currently_paused Number of migration jobs currently considered Paused.
Type: float
Unit: count
jobs_migration_currently_running Number of migration jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_migration_expired_pts_records Number of expired protected timestamp records owned by migration jobs.
Type: float
Unit: count
jobs_migration_fail_or_cancel_completed Number of migration jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_migration_fail_or_cancel_failed Number of migration jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_migration_fail_or_cancel_retry_error Number of migration jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_migration_protected_age_sec The age of the oldest PTS record protected by migration jobs.
Type: float
Unit: time,s
jobs_migration_protected_record Number of protected timestamp records held by migration jobs.
Type: float
Unit: count
jobs_migration_protected_record_count
Type: float
Unit: count
jobs_migration_resume_completed Number of migration jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_migration_resume_failed Number of migration jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_migration_resume_retry_error Number of migration jobs which failed with a retry able error.
Type: float
Unit: count
jobs_mvcc_statistics_update_currently_idle Number of mvcc_statistics_update jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_mvcc_statistics_update_currently_paused Number of mvcc_statistics_update jobs currently considered Paused.
Type: float
Unit: count
jobs_mvcc_statistics_update_currently_running Number of mvcc_statistics_update jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_mvcc_statistics_update_expired_pts_records Number of expired protected timestamp records owned by mvcc_statistics_update jobs.
Type: float
Unit: count
jobs_mvcc_statistics_update_fail_or_cancel_completed Number of mvcc_statistics_update jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_mvcc_statistics_update_fail_or_cancel_failed Number of mvcc_statistics_update jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_mvcc_statistics_update_fail_or_cancel_retry_error Number of mvcc_statistics_update jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_mvcc_statistics_update_protected_age_sec The age of the oldest PTS record protected by mvcc_statistics_update jobs.
Type: float
Unit: time,s
jobs_mvcc_statistics_update_protected_record Number of protected timestamp records held by mvcc_statistics_update jobs.
Type: float
Unit: count
jobs_mvcc_statistics_update_resume_completed Number of mvcc_statistics_update jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_mvcc_statistics_update_resume_failed Number of mvcc_statistics_update jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_mvcc_statistics_update_resume_retry_error Number of mvcc_statistics_update jobs which failed with a retry able error.
Type: float
Unit: count
jobs_new_schema_change_currently_idle Number of new_schema_change jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_new_schema_change_currently_paused Number of new_schema_change jobs currently considered Paused.
Type: float
Unit: count
jobs_new_schema_change_currently_running Number of new_schema_change jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_new_schema_change_expired_pts_records Number of expired protected timestamp records owned by new_schema_change jobs.
Type: float
Unit: count
jobs_new_schema_change_fail_or_cancel_completed Number of new_schema_change jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_new_schema_change_fail_or_cancel_failed Number of new_schema_change jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_new_schema_change_fail_or_cancel_retry_error Number of new_schema_change jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_new_schema_change_protected_age_sec The age of the oldest PTS record protected by new_schema_change jobs.
Type: float
Unit: time,s
jobs_new_schema_change_protected_record Number of protected timestamp records held by new_schema_change jobs.
Type: float
Unit: count
jobs_new_schema_change_resume_completed Number of new_schema_change jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_new_schema_change_resume_failed Number of new_schema_change jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_new_schema_change_resume_retry_error Number of new_schema_change jobs which failed with a retry able error.
Type: float
Unit: count
jobs_poll_jobs_stats_currently_idle Number of poll_jobs_stats jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_poll_jobs_stats_currently_paused Number of poll_jobs_stats jobs currently considered Paused.
Type: float
Unit: count
jobs_poll_jobs_stats_currently_running Number of poll_jobs_stats jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_poll_jobs_stats_expired_pts_records Number of expired protected timestamp records owned by poll_jobs_stats jobs.
Type: float
Unit: count
jobs_poll_jobs_stats_fail_or_cancel_completed Number of poll_jobs_stats jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_poll_jobs_stats_fail_or_cancel_failed Number of poll_jobs_stats jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_poll_jobs_stats_fail_or_cancel_retry_error Number of poll_jobs_stats jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_poll_jobs_stats_protected_age_sec The age of the oldest PTS record protected by poll_jobs_stats jobs.
Type: float
Unit: time,s
jobs_poll_jobs_stats_protected_record Number of protected timestamp records held by poll_jobs_stats jobs.
Type: float
Unit: count
jobs_poll_jobs_stats_resume_completed Number of poll_jobs_stats jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_poll_jobs_stats_resume_failed Number of poll_jobs_stats jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_poll_jobs_stats_resume_retry_error Number of poll_jobs_stats jobs which failed with a retry able error.
Type: float
Unit: count
jobs_replication_stream_ingestion_currently_idle Number of replication_stream_ingestion jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_replication_stream_ingestion_currently_paused Number of replication_stream_ingestion jobs currently considered Paused.
Type: float
Unit: count
jobs_replication_stream_ingestion_currently_running Number of replication_stream_ingestion jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_replication_stream_ingestion_expired_pts_records Number of expired protected timestamp records owned by replication_stream_ingestion jobs.
Type: float
Unit: count
jobs_replication_stream_ingestion_fail_or_cancel_completed Number of replication_stream_ingestion jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_ingestion_fail_or_cancel_failed Number of replication_stream_ingestion jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_ingestion_fail_or_cancel_retry_error Number of replication_stream_ingestion jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_ingestion_protected_age_sec The age of the oldest PTS record protected by replication_stream_ingestion jobs.
Type: float
Unit: time,s
jobs_replication_stream_ingestion_protected_record Number of protected timestamp records held by replication_stream_ingestion jobs.
Type: float
Unit: count
jobs_replication_stream_ingestion_resume_completed Number of replication_stream_ingestion jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_replication_stream_ingestion_resume_failed Number of replication_stream_ingestion jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_replication_stream_ingestion_resume_retry_error Number of replication_stream_ingestion jobs which failed with a retry able error.
Type: float
Unit: count
jobs_replication_stream_producer_currently_idle Number of replication_stream_producer jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_replication_stream_producer_currently_paused Number of replication_stream_producer jobs currently considered Paused.
Type: float
Unit: count
jobs_replication_stream_producer_currently_running Number of replication_stream_producer jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_replication_stream_producer_expired_pts_records Number of expired protected timestamp records owned by replication_stream_producer jobs.
Type: float
Unit: count
jobs_replication_stream_producer_fail_or_cancel_completed Number of replication_stream_producer jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_producer_fail_or_cancel_failed Number of replication_stream_producer jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_producer_fail_or_cancel_retry_error Number of replication_stream_producer jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_replication_stream_producer_protected_age_sec The age of the oldest PTS record protected by replication_stream_producer jobs.
Type: float
Unit: time,s
jobs_replication_stream_producer_protected_record Number of protected timestamp records held by replication_stream_producer jobs.
Type: float
Unit: count
jobs_replication_stream_producer_resume_completed Number of replication_stream_producer jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_replication_stream_producer_resume_failed Number of replication_stream_producer jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_replication_stream_producer_resume_retry_error Number of replication_stream_producer jobs which failed with a retry able error.
Type: float
Unit: count
jobs_restore_currently_idle Number of restore jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_restore_currently_paused Number of restore jobs currently considered Paused.
Type: float
Unit: count
jobs_restore_currently_running Number of restore jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_restore_expired_pts_records Number of expired protected timestamp records owned by restore jobs.
Type: float
Unit: count
jobs_restore_fail_or_cancel_completed Number of restore jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_restore_fail_or_cancel_failed Number of restore jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_restore_fail_or_cancel_retry_error Number of restore jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_restore_protected_age_sec The age of the oldest PTS record protected by restore jobs.
Type: float
Unit: time,s
jobs_restore_protected_record Number of protected timestamp records held by restore jobs.
Type: float
Unit: count
jobs_restore_resume_completed Number of restore jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_restore_resume_failed Number of restore jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_restore_resume_retry_error Number of restore jobs which failed with a retry able error.
Type: float
Unit: count
jobs_resumed_claimed_jobs number of claimed-jobs resumed in job-adopt iterations.
Type: float
Unit: count
jobs_row_level_ttl_currently_idle Number of row_level_ttl jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_row_level_ttl_currently_paused Number of row_level_ttl jobs currently considered Paused.
Type: float
Unit: count
jobs_row_level_ttl_currently_running Number of row_level_ttl jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_row_level_ttl_delete_duration_bucket Duration for delete requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_delete_duration_count Duration for delete requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_delete_duration_sum Duration for delete requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_expired_pts_records Number of expired protected timestamp records owned by row_level_ttl jobs.
Type: float
Unit: count
jobs_row_level_ttl_fail_or_cancel_completed Number of row_level_ttl jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_row_level_ttl_fail_or_cancel_failed Number of row_level_ttl jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_row_level_ttl_fail_or_cancel_retry_error Number of row_level_ttl jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_row_level_ttl_num_active_spans Number of active spans the TTL job is deleting from.
Type: float
Unit: count
jobs_row_level_ttl_protected_age_sec The age of the oldest PTS record protected by row_level_ttl jobs.
Type: float
Unit: time,s
jobs_row_level_ttl_protected_record Number of protected timestamp records held by row_level_ttl jobs.
Type: float
Unit: count
jobs_row_level_ttl_protected_record_count
Type: float
Unit: count
jobs_row_level_ttl_resume_completed Number of row_level_ttl jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_row_level_ttl_resume_failed Number of row_level_ttl jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_row_level_ttl_resume_retry_error Number of row_level_ttl jobs which failed with a retry able error.
Type: float
Unit: count
jobs_row_level_ttl_rows_deleted Number of rows deleted by the row level TTL job.
Type: float
Unit: count
jobs_row_level_ttl_rows_selected Number of rows selected for deletion by the row level TTL job.
Type: float
Unit: count
jobs_row_level_ttl_select_duration_bucket Duration for select requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_select_duration_count Duration for select requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_select_duration_sum Duration for select requests during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_span_total_duration_bucket Duration for processing a span during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_span_total_duration_count Duration for processing a span during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_span_total_duration_sum Duration for processing a span during row level TTL.
Type: float
Unit: time,ns
jobs_row_level_ttl_total_expired_rows Approximate number of rows that have expired the TTL on the TTL table.
Type: float
Unit: count
jobs_row_level_ttl_total_rows Approximate number of rows on the TTL table.
Type: float
Unit: count
jobs_running_non_idle number of running jobs that are not idle.
Type: float
Unit: count
jobs_schema_change_currently_idle Number of schema_change jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_schema_change_currently_paused Number of schema_change jobs currently considered Paused.
Type: float
Unit: count
jobs_schema_change_currently_running Number of schema_change jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_schema_change_expired_pts_records Number of expired protected timestamp records owned by schema_change jobs.
Type: float
Unit: count
jobs_schema_change_fail_or_cancel_completed Number of schema_change jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_fail_or_cancel_failed Number of schema_change jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_fail_or_cancel_retry_error Number of schema_change jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_gc_currently_idle Number of schema_change_gc jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_schema_change_gc_currently_paused Number of schema_change_gc jobs currently considered Paused.
Type: float
Unit: count
jobs_schema_change_gc_currently_running Number of schema_change_gc jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_schema_change_gc_expired_pts_records Number of expired protected timestamp records owned by schema_change_gc jobs.
Type: float
Unit: count
jobs_schema_change_gc_fail_or_cancel_completed Number of schema_change_gc jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_gc_fail_or_cancel_failed Number of schema_change_gc jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_gc_fail_or_cancel_retry_error Number of schema_change_gc jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_schema_change_gc_protected_age_sec The age of the oldest PTS record protected by schema_change_gc jobs.
Type: float
Unit: time,s
jobs_schema_change_gc_protected_record Number of protected timestamp records held by schema_change_gc jobs.
Type: float
Unit: count
jobs_schema_change_gc_resume_completed Number of schema_change_gc jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_schema_change_gc_resume_failed Number of schema_change_gc jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_schema_change_gc_resume_retry_error Number of schema_change_gc jobs which failed with a retry able error.
Type: float
Unit: count
jobs_schema_change_protected_age_sec The age of the oldest PTS record protected by schema_change jobs.
Type: float
Unit: time,s
jobs_schema_change_protected_record Number of protected timestamp records held by schema_change jobs.
Type: float
Unit: count
jobs_schema_change_resume_completed Number of schema_change jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_schema_change_resume_failed Number of schema_change jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_schema_change_resume_retry_error Number of schema_change jobs which failed with a retry able error.
Type: float
Unit: count
jobs_stream_replication_fail_or_cancel_failed
Type: float
Unit: count
jobs_typedesc_schema_change_currently_idle Number of typedesc_schema_change jobs currently considered Idle and can be freely shut down.
Type: float
Unit: count
jobs_typedesc_schema_change_currently_paused Number of typedesc_schema_change jobs currently considered Paused.
Type: float
Unit: count
jobs_typedesc_schema_change_currently_running Number of typedesc_schema_change jobs currently running in Resume or OnFailOrCancel state.
Type: float
Unit: count
jobs_typedesc_schema_change_expired_pts_records Number of expired protected timestamp records owned by typedesc_schema_change jobs.
Type: float
Unit: count
jobs_typedesc_schema_change_fail_or_cancel_completed Number of typedesc_schema_change jobs which successfully completed their failure or cancellation process.
Type: float
Unit: count
jobs_typedesc_schema_change_fail_or_cancel_failed Number of typedesc_schema_change jobs which failed with a non-retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_typedesc_schema_change_fail_or_cancel_retry_error Number of typedesc_schema_change jobs which failed with a retry able error on their failure or cancellation process.
Type: float
Unit: count
jobs_typedesc_schema_change_protected_age_sec The age of the oldest PTS record protected by typedesc_schema_change jobs.
Type: float
Unit: time,s
jobs_typedesc_schema_change_protected_record Number of protected timestamp records held by typedesc_schema_change jobs.
Type: float
Unit: count
jobs_typedesc_schema_change_resume_completed Number of typedesc_schema_change jobs which successfully resumed to completion.
Type: float
Unit: count
jobs_typedesc_schema_change_resume_failed Number of typedesc_schema_change jobs which failed with a non-retry able error.
Type: float
Unit: count
jobs_typedesc_schema_change_resume_retry_error Number of typedesc_schema_change jobs which failed with a retry able error.
Type: float
Unit: count
keybytes [OpenMetrics v1 & v2] Number of bytes taken up by keys.
Type: float
Unit: digital,B
keycount [OpenMetrics v1 & v2] Count of all keys.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_cannot_find_better_candidate The number times the allocator determined that the lease was on the best possible replica.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_delta_not_significant The number times the allocator determined that the delta between the existing store and the best candidate was not significant.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_existing_not_overfull The number times the allocator determined that the lease was not on an overfull store.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_follow_the_workload The number times the allocator determined that the lease should be transferred to another replica for locality.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_missing_stats_for_existing_stores The number times the allocator was missing qps stats for the leaseholder.
Type: float
Unit: count
kv_allocator_load_based_lease_transfers_should_transfer The number times the allocator determined that the lease should be transferred to another replica for better load distribution.
Type: float
Unit: count
kv_allocator_load_based_replica_rebalancing_cannot_find_better_candidate The number times the allocator determined that the range was on the best possible stores.
Type: float
Unit: count
kv_allocator_load_based_replica_rebalancing_delta_not_significant The number times the allocator determined that the delta between an existing store and the best replacement candidate was not high enough.
Type: float
Unit: count
kv_allocator_load_based_replica_rebalancing_existing_not_overfull The number times the allocator determined that none of the range's replicas were on overfull stores.
Type: float
Unit: count
kv_allocator_load_based_replica_rebalancing_missing_stats_for_existing_store The number times the allocator was missing the qps stats for the existing store.
Type: float
Unit: count
kv_allocator_load_based_replica_rebalancing_should_transfer The number times the allocator determined that the replica should be rebalanced to another store for better load distribution.
Type: float
Unit: count
kv_closed_timestamp_max_behind_nanos Largest latency between realtime and replica max closed timestamp.
Type: float
Unit: time,ns
kv_concurrency_avg_lock_hold_duration_nanos Average lock hold duration across locks currently held in lock tables. Does not include replicated locks (intents) that are not held in memory.
Type: float
Unit: time,ns
kv_concurrency_avg_lock_wait_duration_nanos Average lock wait duration across requests currently waiting in lock wait-queues.
Type: float
Unit: time,ns
kv_concurrency_lock_wait_queue_waiters Number of requests actively waiting in a lock wait-queue.
Type: float
Unit: count
kv_concurrency_locks Number of active locks held in lock tables. Does not include replicated locks (intents) that are not held in memory.
Type: float
Unit: count
kv_concurrency_locks_with_wait_queues Number of active locks held in lock tables with active wait-queues.
Type: float
Unit: count
kv_concurrency_max_lock_hold_duration_nanos Maximum length of time any lock in a lock table is held. Does not include replicated locks (intents) that are not held in memory.
Type: float
Unit: time,ns
kv_concurrency_max_lock_wait_duration_nanos Maximum lock wait duration across requests currently waiting in lock wait-queues.
Type: float
Unit: time,ns
kv_concurrency_max_lock_wait_queue_waiters_for_lock Maximum number of requests actively waiting in any single lock wait-queue.
Type: float
Unit: count
kv_loadsplitter_nosplitkey Load-based splitter could not find a split key.
Type: float
Unit: count
kv_loadsplitter_popularkey Load-based splitter could not find a split key and the most popular sampled split key occurs in >= 25% of the samples.
Type: float
Unit: count
kv_prober_planning_attempts Number of attempts at planning out probes made; in order to probe KV we need to plan out which ranges to probe;.
Type: float
Unit: count
kv_prober_planning_failures Number 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 kv prober is not able to send probes to all ranges; consider alerting on this metric as a result.
Type: float
Unit: count
kv_prober_read_attempts Number of attempts made to read probe KV, regardless of outcome.
Type: float
Unit: count
kv_prober_read_failures Number of attempts made to read probe KV that failed, whether due to error or timeout.
Type: float
Unit: count
kv_prober_read_latency_bucket Latency of successful KV read probes.
Type: float
Unit: time,ns
kv_prober_read_latency_count Latency of successful KV read probes.
Type: float
Unit: time,ns
kv_prober_read_latency_sum Latency of successful KV read probes.
Type: float
Unit: time,ns
kv_prober_write_attempts Number of attempts made to write probe KV, regardless of outcome.
Type: float
Unit: count
kv_prober_write_failures Number of attempts made to write probe KV that failed, whether due to error or timeout.
Type: float
Unit: count
kv_prober_write_latency_bucket Latency of successful KV write probes.
Type: float
Unit: time,ns
kv_prober_write_latency_count Latency of successful KV write probes.
Type: float
Unit: time,ns
kv_prober_write_latency_sum Latency of successful KV write probes.
Type: float
Unit: time,ns
kv_prober_write_quarantine_oldest_duration The duration that the oldest range in the write quarantine pool has remained.
Type: float
Unit: time,s
kv_protectedts_reconciliation_errors number of errors encountered during reconciliation runs on this node.
Type: float
Unit: count
kv_protectedts_reconciliation_num_runs number of successful reconciliation runs on this node.
Type: float
Unit: count
kv_protectedts_reconciliation_records_processed number of records processed without error during reconciliation on this node.
Type: float
Unit: count
kv_protectedts_reconciliation_records_removed number of records removed during reconciliation runs on this node.
Type: float
Unit: count
kv_rangefeed_budget_allocation_blocked Number of times RangeFeed waited for budget availability.
Type: float
Unit: count
kv_rangefeed_budget_allocation_failed Number of times RangeFeed failed because memory budget was exceeded.
Type: float
Unit: count
kv_rangefeed_catchup_scan_nanos Time spent in RangeFeed catchup scan.
Type: float
Unit: time,ns
kv_rangefeed_mem_shared Memory usage by range feeds.
Type: float
Unit: digital,B
kv_rangefeed_mem_system Memory usage by range feeds on system ranges.
Type: float
Unit: digital,B
kv_rangefeed_processors_goroutine Number of active RangeFeed processors using goroutines.
Type: float
Unit: count
kv_rangefeed_processors_scheduler Number of active RangeFeed processors using scheduler.
Type: float
Unit: count
kv_rangefeed_registrations Number of active RangeFeed registrations.
Type: float
Unit: count
kv_rangefeed_scheduler_normal_latency_bucket KV RangeFeed normal scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_normal_latency_count KV RangeFeed normal scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_normal_latency_sum KV RangeFeed normal scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_normal_queue_size Number of entries in the KV RangeFeed normal scheduler queue.
Type: float
Unit: count
kv_rangefeed_scheduler_system_latency_bucket KV RangeFeed system scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_system_latency_count KV RangeFeed system scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_system_latency_sum KV RangeFeed system scheduler latency.
Type: float
Unit: time,ns
kv_rangefeed_scheduler_system_queue_size Number of entries in the KV RangeFeed system scheduler queue.
Type: float
Unit: count
kv_replica_circuit_breaker_num_tripped_events Number of times the per-Replica circuit breakers tripped since process start.
Type: float
Unit: count
kv_replica_circuit_breaker_num_tripped_replicas Number 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.
Type: float
Unit: count
kv_replica_read_batch_evaluate_dropped_latches_before_eval Number of times read-only batches dropped latches before evaluation.
Type: float
Unit: count
kv_replica_read_batch_evaluate_latency_bucket Execution 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.
Type: float
Unit: time,ns
kv_replica_read_batch_evaluate_latency_count Execution 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.
Type: float
Unit: time,ns
kv_replica_read_batch_evaluate_latency_sum Execution 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.
Type: float
Unit: time,ns
kv_replica_read_batch_evaluate_without_interleaving_iter Number of read-only batches evaluated without an intent interleaving iter.
Type: float
Unit: count
kv_replica_write_batch_evaluate_latency_bucket Execution 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.
Type: float
Unit: time,ns
kv_replica_write_batch_evaluate_latency_count Execution 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.
Type: float
Unit: time,ns
kv_replica_write_batch_evaluate_latency_sum Execution 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.
Type: float
Unit: time,ns
kv_tenant_rate_limit_current_blocked Number of requests currently blocked by the rate limiter.
Type: float
Unit: count
kv_tenant_rate_limit_num_tenants Number of tenants currently being tracked.
Type: float
Unit: count
kv_tenant_rate_limit_read_batches_admitted Number of read batches admitted by the rate limiter.
Type: float
Unit: count
kv_tenant_rate_limit_read_bytes_admitted Number of read bytes admitted by the rate limiter.
Type: float
Unit: digital,B
kv_tenant_rate_limit_read_requests_admitted Number of read requests admitted by the rate limiter.
Type: float
Unit: count
kv_tenant_rate_limit_write_batches_admitted Number of write batches admitted by the rate limiter.
Type: float
Unit: count
kv_tenant_rate_limit_write_bytes_admitted Number of write bytes admitted by the rate limiter.
Type: float
Unit: digital,B
kv_tenant_rate_limit_write_requests_admitted Number of write requests admitted by the rate limiter.
Type: float
Unit: count
kvadmission_flow_controller_elastic_blocked_stream_count Number of replication streams with no flow tokens available for elastic requests.
Type: float
Unit: count
kvadmission_flow_controller_elastic_requests_admitted Number of elastic requests admitted by the flow controller.
Type: float
Unit: count
kvadmission_flow_controller_elastic_requests_bypassed Number of elastic waiting requests that bypassed the flow controller due to disconnecting streams.
Type: float
Unit: count
kvadmission_flow_controller_elastic_requests_errored Number of elastic requests that errored out while waiting for flow tokens.
Type: float
Unit: count
kvadmission_flow_controller_elastic_requests_waiting Number of elastic requests waiting for flow tokens.
Type: float
Unit: count
kvadmission_flow_controller_elastic_stream_count Total number of replication streams for elastic requests.
Type: float
Unit: count
kvadmission_flow_controller_elastic_tokens_available Flow tokens available for elastic requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_elastic_tokens_deducted Flow tokens deducted by elastic requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_elastic_tokens_returned Flow tokens returned by elastic requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_elastic_tokens_unaccounted Flow tokens returned by elastic requests that were unaccounted for, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_elastic_wait_duration_bucket Latency histogram for time elastic requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_controller_elastic_wait_duration_count Latency histogram for time elastic requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_controller_elastic_wait_duration_sum Latency histogram for time elastic requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_controller_regular_blocked_stream_count Number of replication streams with no flow tokens available for regular requests.
Type: float
Unit: count
kvadmission_flow_controller_regular_requests_admitted Number of regular requests admitted by the flow controller.
Type: float
Unit: count
kvadmission_flow_controller_regular_requests_bypassed Number of regular waiting requests that bypassed the flow controller due to disconnecting streams.
Type: float
Unit: count
kvadmission_flow_controller_regular_requests_errored Number of regular requests that errored out while waiting for flow tokens.
Type: float
Unit: count
kvadmission_flow_controller_regular_requests_waiting Number of regular requests waiting for flow tokens.
Type: float
Unit: count
kvadmission_flow_controller_regular_stream_count Total number of replication streams for regular requests.
Type: float
Unit: count
kvadmission_flow_controller_regular_tokens_available Flow tokens available for regular requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_regular_tokens_deducted Flow tokens deducted by regular requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_regular_tokens_returned Flow tokens returned by regular requests, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_regular_tokens_unaccounted Flow tokens returned by regular requests that were unaccounted for, across all replication streams.
Type: float
Unit: digital,B
kvadmission_flow_controller_regular_wait_duration_bucket Latency histogram for time regular requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_controller_regular_wait_duration_count Latency histogram for time regular requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_controller_regular_wait_duration_sum Latency histogram for time regular requests spent waiting for flow tokens.
Type: float
Unit: time,ns
kvadmission_flow_handle_elastic_requests_admitted Number of elastic requests admitted by the flow handle.
Type: float
Unit: count
kvadmission_flow_handle_elastic_requests_errored Number of elastic requests that errored out while waiting for flow tokens, at the handle level.
Type: float
Unit: count
kvadmission_flow_handle_elastic_requests_waiting Number of elastic requests waiting for flow tokens, at the handle level.
Type: float
Unit: count
kvadmission_flow_handle_elastic_wait_duration_bucket Latency histogram for time elastic requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_elastic_wait_duration_count Latency histogram for time elastic requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_elastic_wait_duration_sum Latency histogram for time elastic requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_regular_requests_admitted Number of regular requests admitted by the flow handle.
Type: float
Unit: count
kvadmission_flow_handle_regular_requests_errored Number of regular requests that errored out while waiting for flow tokens, at the handle level.
Type: float
Unit: count
kvadmission_flow_handle_regular_requests_waiting Number of regular requests waiting for flow tokens, at the handle level.
Type: float
Unit: count
kvadmission_flow_handle_regular_wait_duration_bucket Latency histogram for time regular requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_regular_wait_duration_count Latency histogram for time regular requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_regular_wait_duration_sum Latency histogram for time regular requests spent waiting for flow tokens, at the handle level.
Type: float
Unit: time,ns
kvadmission_flow_handle_streams_connected Number of times we've connected to a stream, at the handle level.
Type: float
Unit: count
kvadmission_flow_handle_streams_disconnected Number of times we've disconnected from a stream, at the handle level.
Type: float
Unit: count
kvadmission_flow_token_dispatch_coalesced_elastic Number of coalesced elastic flow token dispatches (where we're informing the sender of a higher log entry being admitted).
Type: float
Unit: count
kvadmission_flow_token_dispatch_coalesced_regular Number of coalesced regular flow token dispatches (where we're informing the sender of a higher log entry being admitted).
Type: float
Unit: count
kvadmission_flow_token_dispatch_local_elastic Number of local elastic flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_local_regular Number of local regular flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_pending_elastic Number of pending elastic flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_pending_nodes Number of nodes pending flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_pending_regular Number of pending regular flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_remote_elastic Number of remote elastic flow token dispatches.
Type: float
Unit: count
kvadmission_flow_token_dispatch_remote_regular Number of remote regular flow token dispatches.
Type: float
Unit: count
lastupdatenanos [OpenMetrics v1 & v2] Time in nanoseconds since Unix epoch at which bytes/keys/intents metrics were last updated.
Type: float
Unit: time,ns
leases_epoch [OpenMetrics v1 & v2] Number of replica leaseholders using epoch-based leases.
Type: float
Unit: count
leases_error [OpenMetrics v1] Number of failed lease requests.
Type: float
Unit: count
leases_error_count [OpenMetrics v2] Number of failed lease requests.
Type: float
Unit: count
leases_expiration [OpenMetrics v1 & v2] Number of replica leaseholders using expiration-based leases.
Type: float
Unit: count
leases_liveness Number of replica leaseholders for the liveness range(s).
Type: float
Unit: count
leases_preferences_less_preferred Number of replica leaseholders which satisfy a lease preference which is not the most preferred.
Type: float
Unit: count
leases_preferences_violating Number of replica leaseholders which violate lease preferences.
Type: float
Unit: count
leases_requests_latency_bucket Lease request latency (all types and outcomes, coalesced).
Type: float
Unit: time,ns
leases_requests_latency_count Lease request latency (all types and outcomes, coalesced).
Type: float
Unit: time,ns
leases_requests_latency_sum Lease request latency (all types and outcomes, coalesced).
Type: float
Unit: time,ns
leases_success [OpenMetrics v1] Number of successful lease requests.
Type: float
Unit: count
leases_success_count [OpenMetrics v2] Number of successful lease requests.
Type: float
Unit: count
leases_transfers_error [OpenMetrics v1] Number of failed lease transfers.
Type: float
Unit: count
leases_transfers_error_count [OpenMetrics v2] Number of failed lease transfers.
Type: float
Unit: count
leases_transfers_success [OpenMetrics v1] Number of successful lease transfers.
Type: float
Unit: count
leases_transfers_success_count [OpenMetrics v2] Number of successful lease transfers.
Type: float
Unit: count
livebytes [OpenMetrics v1 & v2] Number of bytes of live data (keys plus values).
Type: float
Unit: digital,B
livecount [OpenMetrics v1 & v2] Count of live keys.
Type: float
Unit: count
liveness_epochincrements [OpenMetrics v1] Number of times this node has incremented its liveness epoch.
Type: float
Unit: count
liveness_epochincrements_count [OpenMetrics v2] Number of times this node has incremented its liveness epoch.
Type: float
Unit: count
liveness_heartbeatfailures [OpenMetrics v1] Number of failed node liveness heartbeats from this node.
Type: float
Unit: count
liveness_heartbeatfailures_count [OpenMetrics v2] Number of failed node liveness heartbeats from this node.
Type: float
Unit: count
liveness_heartbeatlatency [OpenMetrics v1] Node liveness heartbeat latency in nanoseconds.
Type: float
Unit: time,ns
liveness_heartbeatlatency_bucket [OpenMetrics v2] Node liveness heartbeat latency in nanoseconds.
Type: float
Unit: time,ns
liveness_heartbeatlatency_count [OpenMetrics v2] Node liveness heartbeat latency in nanoseconds.
Type: float
Unit: time,ns
liveness_heartbeatlatency_sum [OpenMetrics v2] Node liveness heartbeat latency in nanoseconds.
Type: float
Unit: time,ns
liveness_heartbeatsinflight Number of in-flight liveness heartbeats from this node.
Type: float
Unit: count
liveness_heartbeatsuccesses [OpenMetrics v1] Number of successful node liveness heartbeats from this node.
Type: float
Unit: count
liveness_heartbeatsuccesses_count [OpenMetrics v2] Number of successful node liveness heartbeats from this node.
Type: float
Unit: count
liveness_livenodes [OpenMetrics v1 & v2] Number of live nodes in the cluster (will be 0 if this node is not itself live).
Type: float
Unit: count
lockbytes Number of bytes taken up by replicated lock key-values (shared and exclusive strength, not intent strength).
Type: float
Unit: digital,B
lockcount Count of replicated locks (shared, exclusive, and intent strength).
Type: float
Unit: count
log_buffered_messages_dropped Count of log messages that are dropped by buffered log sinks. When CockroachDB 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 message.
Type: float
Unit: count
log_fluent_sink_conn_errors Number of connection errors experienced by fluent-server logging sinks.
Type: float
Unit: count
log_messages_count Count 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.
Type: float
Unit: count
node_id [OpenMetrics v1 & v2] node ID with labels for advertised RPC and HTTP addresses.
Type: float
Unit: count
physical_replication_admit_latency_bucket Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into ingestion processor.
Type: float
Unit: time,ns
physical_replication_admit_latency_count Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into ingestion processor.
Type: float
Unit: time,ns
physical_replication_admit_latency_sum Event admission latency: a difference between event Multi-Version Concurrency Control timestamp and the time it was admitted into ingestion processor.
Type: float
Unit: time,ns
physical_replication_commit_latency_bucket Event commit latency: a difference between event Multi-Version Concurrency Control 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 recorded.
Type: float
Unit: time,ns
physical_replication_commit_latency_count Event commit latency: a difference between event Multi-Version Concurrency Control 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 recorded.
Type: float
Unit: time,ns
physical_replication_commit_latency_sum Event commit latency: a difference between event Multi-Version Concurrency Control 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 recorded.
Type: float
Unit: time,ns
physical_replication_cutover_progress The number of ranges left to revert in order to complete an inflight cut over.
Type: float
Unit: count
physical_replication_distsql_replan_count Total number of dist SQL replanning events.
Type: float
Unit: count
physical_replication_earliest_data_checkpoint_span The earliest timestamp of the last checkpoint forwarded by an ingestion data processor.
Type: float
Unit: count
physical_replication_events_ingested Events ingested by all replication jobs.
Type: float
Unit: count
physical_replication_flush_hist_nanos_bucket Time spent flushing messages across all replication streams.
Type: float
Unit: time,ns
physical_replication_flush_hist_nanos_count Time spent flushing messages across all replication streams.
Type: float
Unit: time,ns
physical_replication_flush_hist_nanos_sum Time spent flushing messages across all replication streams.
Type: float
Unit: time,ns
physical_replication_flushes Total flushes across all replication jobs.
Type: float
Unit: count
physical_replication_job_progress_updates Total number of updates to the ingestion job progress.
Type: float
Unit: count
physical_replication_latest_data_checkpoint_span The latest timestamp of the last checkpoint forwarded by an ingestion data processor.
Type: float
Unit: count
physical_replication_logical_bytes Logical bytes (sum of keys + values) ingested by all replication jobs.
Type: float
Unit: digital,B
physical_replication_replicated_time_seconds The replicated time of the physical replication stream in seconds since the unix epoch.
Type: float
Unit: time,s
physical_replication_resolved_events_ingested Resolved events ingested by all replication jobs.
Type: float
Unit: count
physical_replication_running Number of currently running replication streams.
Type: float
Unit: count
physical_replication_sst_bytes SST bytes (compressed) sent to KV by all replication jobs.
Type: float
Unit: digital,B
queue_consistency_pending [OpenMetrics v1 & v2] Number of pending replicas in the consistency checker queue.
Type: float
Unit: count
queue_consistency_process_failure [OpenMetrics v1] Number of replicas which failed processing in the consistency checker queue.
Type: float
Unit: count
queue_consistency_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the consistency checker queue.
Type: float
Unit: count
queue_consistency_process_success [OpenMetrics v1] Number of replicas successfully processed by the consistency checker queue.
Type: float
Unit: count
queue_consistency_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the consistency checker queue.
Type: float
Unit: count
queue_consistency_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the consistency checker queue.
Type: float
Unit: time,ns
queue_consistency_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the consistency checker queue.
Type: float
Unit: time,ns
queue_gc_info_abortspanconsidered [OpenMetrics v1] Number of AbortSpan entries old enough to be considered for removal.
Type: float
Unit: count
queue_gc_info_abortspanconsidered_count [OpenMetrics v2] Number of AbortSpan entries old enough to be considered for removal.
Type: float
Unit: count
queue_gc_info_abortspangcnum [OpenMetrics v1] Number of AbortSpan entries fit for removal.
Type: float
Unit: count
queue_gc_info_abortspangcnum_count [OpenMetrics v2] Number of AbortSpan entries fit for removal.
Type: float
Unit: count
queue_gc_info_abortspanscanned [OpenMetrics v1] Number of transactions present in the AbortSpan scanned from the engine.
Type: float
Unit: percent,percent
queue_gc_info_abortspanscanned_count [OpenMetrics v2] Number of transactions present in the AbortSpan scanned from the engine.
Type: float
Unit: percent,percent
queue_gc_info_clearrangefailed Number of failed ClearRange operations during GC.
Type: float
Unit: count
queue_gc_info_clearrangesuccess Number of successful ClearRange operations during GC.
Type: float
Unit: count
queue_gc_info_enqueuehighpriority Number of replicas enqueued for GC with high priority.
Type: float
Unit: count
queue_gc_info_intentsconsidered [OpenMetrics v1] Number of 'old' intents.
Type: float
Unit: count
queue_gc_info_intentsconsidered_count [OpenMetrics v2] Number of 'old' intents.
Type: float
Unit: count
queue_gc_info_intenttxns [OpenMetrics v1] Number of associated distinct transactions.
Type: float
Unit: percent,percent
queue_gc_info_intenttxns_count [OpenMetrics v2] Number of associated distinct transactions.
Type: float
Unit: percent,percent
queue_gc_info_numkeysaffected [OpenMetrics v1] Number of keys with GC'able data.
Type: float
Unit: count
queue_gc_info_numkeysaffected_count [OpenMetrics v2] Number of keys with GC'able data.
Type: float
Unit: count
queue_gc_info_numrangekeysaffected Number of range keys GC'able.
Type: float
Unit: count
queue_gc_info_pushtxn [OpenMetrics v1] Number of attempted pushes.
Type: float
Unit: count
queue_gc_info_pushtxn_count [OpenMetrics v2] Number of attempted pushes.
Type: float
Unit: count
queue_gc_info_resolvefailed Number of cleanup intent failures during GC.
Type: float
Unit: count
queue_gc_info_resolvesuccess [OpenMetrics v1] Number of successful intent resolutions.
Type: float
Unit: count
queue_gc_info_resolvesuccess_count [OpenMetrics v2] Number of successful intent resolutions.
Type: float
Unit: count
queue_gc_info_resolvetotal [OpenMetrics v1] Number of attempted intent resolutions.
Type: float
Unit: count
queue_gc_info_resolvetotal_count [OpenMetrics v2] Number of attempted intent resolutions.
Type: float
Unit: count
queue_gc_info_transactionresolvefailed Number of intent cleanup failures for local transactions during GC.
Type: float
Unit: count
queue_gc_info_transactionspangcaborted [OpenMetrics v1] Number of GC'able entries corresponding to aborted txns.
Type: float
Unit: count
queue_gc_info_transactionspangcaborted_count [OpenMetrics v2] Number of GC'able entries corresponding to aborted txns.
Type: float
Unit: count
queue_gc_info_transactionspangccommitted [OpenMetrics v1] Number of GC'able entries corresponding to committed txns.
Type: float
Unit: count
queue_gc_info_transactionspangccommitted_count [OpenMetrics v2] Number of GC'able entries corresponding to committed txns.
Type: float
Unit: count
queue_gc_info_transactionspangcpending [OpenMetrics v1] Number of GC'able entries corresponding to pending txns.
Type: float
Unit: count
queue_gc_info_transactionspangcpending_count [OpenMetrics v2] Number of GC'able entries corresponding to pending txns.
Type: float
Unit: count
queue_gc_info_transactionspangcstaging Number of GC'able entries corresponding to staging txns.
Type: float
Unit: count
queue_gc_info_transactionspanscanned [OpenMetrics v1] Number of entries in transaction spans scanned from the engine.
Type: float
Unit: count
queue_gc_info_transactionspanscanned_count [OpenMetrics v2] Number of entries in transaction spans scanned from the engine.
Type: float
Unit: count
queue_gc_pending [OpenMetrics v1 & v2] Number of pending replicas in the GC queue.
Type: float
Unit: count
queue_gc_process_failure [OpenMetrics v1] Number of replicas which failed processing in the GC queue.
Type: float
Unit: count
queue_gc_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the GC queue.
Type: float
Unit: count
queue_gc_process_success [OpenMetrics v1] Number of replicas successfully processed by the GC queue.
Type: float
Unit: count
queue_gc_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the GC queue.
Type: float
Unit: count
queue_gc_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the GC queue.
Type: float
Unit: time,ns
queue_gc_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the GC queue.
Type: float
Unit: time,ns
queue_merge_pending Number of pending replicas in the merge queue.
Type: float
Unit: count
queue_merge_process_failure Number of replicas which failed processing in the merge queue.
Type: float
Unit: count
queue_merge_process_success Number of replicas successfully processed by the merge queue.
Type: float
Unit: count
queue_merge_processingnanos Nanoseconds spent processing replicas in the merge queue.
Type: float
Unit: time,ns
queue_merge_purgatory Number of replicas in the merge queue's purgatory, waiting to become merge able.
Type: float
Unit: count
queue_raftlog_pending [OpenMetrics v1 & v2] Number of pending replicas in the Raft log queue.
Type: float
Unit: count
queue_raftlog_process_failure [OpenMetrics v1] Number of replicas which failed processing in the Raft log queue.
Type: float
Unit: count
queue_raftlog_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the Raft log queue.
Type: float
Unit: count
queue_raftlog_process_success [OpenMetrics v1] Number of replicas successfully processed by the Raft log queue.
Type: float
Unit: count
queue_raftlog_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the Raft log queue.
Type: float
Unit: count
queue_raftlog_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the Raft log queue.
Type: float
Unit: time,ns
queue_raftlog_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the Raft log queue.
Type: float
Unit: time,ns
queue_raftsnapshot_pending [OpenMetrics v1 & v2] Number of pending replicas in the Raft repair queue.
Type: float
Unit: count
queue_raftsnapshot_process_failure [OpenMetrics v1] Number of replicas which failed processing in the Raft repair queue.
Type: float
Unit: count
queue_raftsnapshot_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the Raft repair queue.
Type: float
Unit: count
queue_raftsnapshot_process_success [OpenMetrics v1] Number of replicas successfully processed by the Raft repair queue.
Type: float
Unit: count
queue_raftsnapshot_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the Raft repair queue.
Type: float
Unit: count
queue_raftsnapshot_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the Raft repair queue.
Type: float
Unit: time,ns
queue_raftsnapshot_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the Raft repair queue.
Type: float
Unit: time,ns
queue_replicagc_pending [OpenMetrics v1 & v2] Number of pending replicas in the replica GC queue.
Type: float
Unit: count
queue_replicagc_process_failure [OpenMetrics v1] Number of replicas which failed processing in the replica GC queue.
Type: float
Unit: count
queue_replicagc_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the replica GC queue.
Type: float
Unit: count
queue_replicagc_process_success [OpenMetrics v1] Number of replicas successfully processed by the replica GC queue.
Type: float
Unit: count
queue_replicagc_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the replica GC queue.
Type: float
Unit: count
queue_replicagc_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the replica GC queue.
Type: float
Unit: time,ns
queue_replicagc_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the replica GC queue.
Type: float
Unit: time,ns
queue_replicagc_removereplica [OpenMetrics v1] Number of replica removals attempted by the replica gc queue.
Type: float
Unit: count
queue_replicagc_removereplica_count [OpenMetrics v2] Number of replica removals attempted by the replica gc queue.
Type: float
Unit: count
queue_replicate_addnonvoterreplica Number of non-voter replica additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_addreplica [OpenMetrics v1] Number of replica additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_addreplica_count [OpenMetrics v2] Number of replica additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_addreplica_error Number of failed replica additions processed by the replicate queue.
Type: float
Unit: count
queue_replicate_addreplica_success Number of successful replica additions processed by the replicate queue.
Type: float
Unit: count
queue_replicate_addvoterreplica Number of voter replica additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_nonvoterpromotions Number of non-voters promoted to voters by the replicate queue.
Type: float
Unit: count
queue_replicate_pending [OpenMetrics v1 & v2] Number of pending replicas in the replicate queue.
Type: float
Unit: count
queue_replicate_process_failure [OpenMetrics v1] Number of replicas which failed processing in the replicate queue.
Type: float
Unit: count
queue_replicate_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the replicate queue.
Type: float
Unit: count
queue_replicate_process_success [OpenMetrics v1] Number of replicas successfully processed by the replicate queue.
Type: float
Unit: count
queue_replicate_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the replicate queue.
Type: float
Unit: count
queue_replicate_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the replicate queue.
Type: float
Unit: time,ns
queue_replicate_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the replicate queue.
Type: float
Unit: time,ns
queue_replicate_purgatory [OpenMetrics v1 & v2] Number of replicas in the replicate queue's purgatory, awaiting allocation options.
Type: float
Unit: count
queue_replicate_rebalancenonvoterreplica Number of non-voter replica rebalancer-initiated additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_rebalancereplica [OpenMetrics v1] Number of replica rebalancer-initiated additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_rebalancereplica_count [OpenMetrics v2] Number of replica rebalancer-initiated additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_rebalancevoterreplica Number of voter replica rebalancer-initiated additions attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_removedeadnonvoterreplica Number of dead non-voter replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedeadreplica [OpenMetrics v1] Number of dead replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedeadreplica_count [OpenMetrics v2] Number of dead replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedeadreplica_error Number of failed dead replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removedeadreplica_success Number of successful dead replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removedeadvoterreplica Number of dead voter replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedecommissioningnonvoterreplica Number of decommissioning non-voter replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedecommissioningreplica Number of decommissioning replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removedecommissioningreplica_error Number of failed decommissioning replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removedecommissioningreplica_success Number of successful decommissioning replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removedecommissioningvoterreplica Number of decommissioning voter replica removals attempted by the replicate queue (typically in response to a node outage).
Type: float
Unit: count
queue_replicate_removelearnerreplica Number of learner replica removals attempted by the replicate queue (typically due to internal race conditions).
Type: float
Unit: count
queue_replicate_removenonvoterreplica Number of non-voter replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition).
Type: float
Unit: count
queue_replicate_removereplica [OpenMetrics v1] Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition).
Type: float
Unit: count
queue_replicate_removereplica_count [OpenMetrics v2] Number of replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition).
Type: float
Unit: count
queue_replicate_removereplica_error Number of failed replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removereplica_success Number of successful replica removals processed by the replicate queue.
Type: float
Unit: count
queue_replicate_removevoterreplica Number of voter replica removals attempted by the replicate queue (typically in response to a rebalancer-initiated addition).
Type: float
Unit: count
queue_replicate_replacedeadreplica_error Number of failed dead replica replacements processed by the replicate queue.
Type: float
Unit: count
queue_replicate_replacedeadreplica_success Number of successful dead replica replacements processed by the replicate queue.
Type: float
Unit: count
queue_replicate_replacedecommissioningreplica_error Number of failed decommissioning replica replica replacements processed by the replicate queue.
Type: float
Unit: count
queue_replicate_replacedecommissioningreplica_success Number of successful decommissioning replica replacements processed by the replicate queue.
Type: float
Unit: count
queue_replicate_transferlease [OpenMetrics v1] Number of range lease transfers attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_transferlease_count [OpenMetrics v2] Number of range lease transfers attempted by the replicate queue.
Type: float
Unit: count
queue_replicate_voterdemotions Number of voters demoted to non-voters by the replicate queue.
Type: float
Unit: count
queue_split_load_based Number of range splits due to a range being greater than the configured max range load.
Type: float
Unit: count
queue_split_pending [OpenMetrics v1 & v2] Number of pending replicas in the split queue.
Type: float
Unit: count
queue_split_process_failure [OpenMetrics v1] Number of replicas which failed processing in the split queue.
Type: float
Unit: count
queue_split_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the split queue.
Type: float
Unit: count
queue_split_process_success [OpenMetrics v1] Number of replicas successfully processed by the split queue.
Type: float
Unit: count
queue_split_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the split queue.
Type: float
Unit: count
queue_split_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the split queue.
Type: float
Unit: time,ns
queue_split_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the split queue.
Type: float
Unit: time,ns
queue_split_purgatory Number of replicas in the split queue's purgatory, waiting to become split table.
Type: float
Unit: count
queue_split_size_based Number of range splits due to a range being greater than the configured max range size.
Type: float
Unit: count
queue_split_span_config_based Number of range splits due to span configuration.
Type: float
Unit: count
queue_tsmaintenance_pending [OpenMetrics v1 & v2] Number of pending replicas in the time series maintenance queue.
Type: float
Unit: count
queue_tsmaintenance_process_failure [OpenMetrics v1] Number of replicas which failed processing in the time series maintenance queue.
Type: float
Unit: count
queue_tsmaintenance_process_failure_count [OpenMetrics v2] Number of replicas which failed processing in the time series maintenance queue.
Type: float
Unit: count
queue_tsmaintenance_process_success [OpenMetrics v1] Number of replicas successfully processed by the time series maintenance queue.
Type: float
Unit: count
queue_tsmaintenance_process_success_count [OpenMetrics v2] Number of replicas successfully processed by the time series maintenance queue.
Type: float
Unit: count
queue_tsmaintenance_processingnanos [OpenMetrics v1] Nanoseconds spent processing replicas in the time series maintenance queue.
Type: float
Unit: time,ns
queue_tsmaintenance_processingnanos_count [OpenMetrics v2] Nanoseconds spent processing replicas in the time series maintenance queue.
Type: float
Unit: time,ns
raft_commands_proposed Number of Raft commands proposed.The number of proposals and all kinds of re_proposals made by leaseholders. This metric approximates the number of commands submitted through Raft.
Type: float
Unit: count
raft_commands_reproposed_new_lai Number 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.
Type: float
Unit: count
raft_commands_reproposed_unchanged Number 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 at timeout, and have a high chance of being dropped.
Type: float
Unit: count
raft_commandsapplied [OpenMetrics v1] Count of Raft commands applied.
Type: float
Unit: count
raft_commandsapplied_count [OpenMetrics v2] Count of Raft commands applied.
Type: float
Unit: count
raft_dropped Number of Raft proposals dropped (this counts indivi dial raftpb.Entry, not raftpb.MsgProp).
Type: float
Unit: count
raft_dropped_leader Number of Raft proposals dropped by a Replica that believes itself to be the leader; each update also increments raft.dropped (this counts indivi dial raftpb.Entry, not raftpb.MsgProp).
Type: float
Unit: count
raft_enqueued_pending [OpenMetrics v1 & v2] Number of pending outgoing messages in the Raft Transport queue.
Type: float
Unit: count
raft_entrycache_accesses Number of cache lookups in the Raft entry cache.
Type: float
Unit: count
raft_entrycache_bytes Aggregate size of all Raft entries in the Raft entry cache.
Type: float
Unit: digital,B
raft_entrycache_hits Number of successful cache lookups in the Raft entry cache.
Type: float
Unit: count
raft_entrycache_read_bytes Counter of bytes in entries returned from the Raft entry cache.
Type: float
Unit: digital,B
raft_entrycache_size Number of Raft entries in the Raft entry cache.
Type: float
Unit: count
raft_heartbeats_pending [OpenMetrics v1 & v2] Number of pending heartbeats and responses waiting to be coalesced.
Type: float
Unit: count
raft_process_applycommitted_latency_bucket Latency 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 data points for each sub-batch processed in the process.
Type: float
Unit: time,ns
raft_process_applycommitted_latency_count Latency 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 data points for each sub-batch processed in the process.
Type: float
Unit: time,ns
raft_process_applycommitted_latency_sum Latency 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 data points for each sub-batch processed in the process.
Type: float
Unit: time,ns
raft_process_commandcommit_latency [OpenMetrics v1] Latency histogram in nanoseconds for committing Raft commands.
Type: float
Unit: time,ns
raft_process_commandcommit_latency_bucket [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands.
Type: float
Unit: time,ns
raft_process_commandcommit_latency_count [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands.
Type: float
Unit: time,ns
raft_process_commandcommit_latency_sum [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft commands.
Type: float
Unit: time,ns
raft_process_handleready_latency_bucket Latency 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).
Type: float
Unit: time,ns
raft_process_handleready_latency_count Latency 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).
Type: float
Unit: time,ns
raft_process_handleready_latency_sum Latency 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).
Type: float
Unit: time,ns
raft_process_logcommit_latency [OpenMetrics v1] Latency histogram in nanoseconds for committing Raft log entries.
Type: float
Unit: time,ns
raft_process_logcommit_latency_bucket [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries.
Type: float
Unit: time,ns
raft_process_logcommit_latency_count [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries.
Type: float
Unit: time,ns
raft_process_logcommit_latency_sum [OpenMetrics v2] Latency histogram in nanoseconds for committing Raft log entries.
Type: float
Unit: time,ns
raft_process_tickingnanos [OpenMetrics v1] Nanoseconds spent in store.processRaft() processing replica.Tick().
Type: float
Unit: time,ns
raft_process_tickingnanos_count [OpenMetrics v2] Nanoseconds spent in store.processRaft() processing replica.Tick().
Type: float
Unit: time,ns
raft_process_workingnanos [OpenMetrics v1] Nanoseconds spent in store.processRaft() working.
Type: float
Unit: time,ns
raft_process_workingnanos_count [OpenMetrics v2] Nanoseconds spent in store.processRaft() working.
Type: float
Unit: time,ns
raft_quota_pool_percent_used_bucket Histogram of proposal quota pool utilization (0-100) per leaseholder per metrics interval.
Type: float
Unit: count
raft_quota_pool_percent_used_count Histogram of proposal quota pool utilization (0-100) per leaseholder per metrics interval.
Type: float
Unit: count
raft_quota_pool_percent_used_sum Histogram of proposal quota pool utilization (0-100) per leaseholder per metrics interval.
Type: float
Unit: count
raft_rcvd_app [OpenMetrics v1] Number of MsgApp messages received by this store.
Type: float
Unit: count
raft_rcvd_app_count [OpenMetrics v2] Number of MsgApp messages received by this store.
Type: float
Unit: count
raft_rcvd_appresp [OpenMetrics v1] Number of MsgAppResp messages received by this store.
Type: float
Unit: count
raft_rcvd_appresp_count [OpenMetrics v2] Number of MsgAppResp messages received by this store.
Type: float
Unit: count
raft_rcvd_bytes Number of bytes in Raft messages received by this store. Note that this does not include raft snapshot received.
Type: float
Unit: digital,B
raft_rcvd_cross_region_bytes Number 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.
Type: float
Unit: digital,B
raft_rcvd_cross_zone_bytes Number 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.
Type: float
Unit: digital,B
raft_rcvd_dropped [OpenMetrics v1] Number of dropped incoming Raft messages.
Type: float
Unit: count
raft_rcvd_dropped_bytes Bytes of dropped incoming Raft messages.
Type: float
Unit: digital,B
raft_rcvd_dropped_count [OpenMetrics v2] Number of dropped incoming Raft messages.
Type: float
Unit: count
raft_rcvd_heartbeat [OpenMetrics v1] Number of (coalesced, if enabled) MsgHeartbeat messages received by this store.
Type: float
Unit: count
raft_rcvd_heartbeat_count [OpenMetrics v2] Number of (coalesced, if enabled) MsgHeartbeat messages received by this store.
Type: float
Unit: count
raft_rcvd_heartbeatresp [OpenMetrics v1] Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store.
Type: float
Unit: count
raft_rcvd_heartbeatresp_count [OpenMetrics v2] Number of (coalesced, if enabled) MsgHeartbeatResp messages received by this store.
Type: float
Unit: count
raft_rcvd_prevote [OpenMetrics v1] Number of MsgPreVote messages received by this store.
Type: float
Unit: count
raft_rcvd_prevote_count [OpenMetrics v2] Number of MsgPreVote messages received by this store.
Type: float
Unit: count
raft_rcvd_prevoteresp [OpenMetrics v1] Number of MsgPreVoteResp messages received by this store.
Type: float
Unit: count
raft_rcvd_prevoteresp_count [OpenMetrics v2] Number of MsgPreVoteResp messages received by this store.
Type: float
Unit: count
raft_rcvd_prop [OpenMetrics v1] Number of MsgProp messages received by this store.
Type: float
Unit: count
raft_rcvd_prop_count [OpenMetrics v2] Number of MsgProp messages received by this store.
Type: float
Unit: count
raft_rcvd_queued_bytes Number of bytes in messages currently waiting for raft processing.
Type: float
Unit: digital,B
raft_rcvd_snap [OpenMetrics v1] Number of MsgSnap messages received by this store.
Type: float
Unit: count
raft_rcvd_snap_count [OpenMetrics v2] Number of MsgSnap messages received by this store.
Type: float
Unit: count
raft_rcvd_stepped_bytes Number 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.
Type: float
Unit: digital,B
raft_rcvd_timeoutnow [OpenMetrics v1] Number of MsgTimeoutNow messages received by this store.
Type: float
Unit: count
raft_rcvd_timeoutnow_count [OpenMetrics v2] Number of MsgTimeoutNow messages received by this store.
Type: float
Unit: count
raft_rcvd_transferleader [OpenMetrics v1] Number of MsgTransferLeader messages received by this store.
Type: float
Unit: count
raft_rcvd_transferleader_count [OpenMetrics v2] Number of MsgTransferLeader messages received by this store.
Type: float
Unit: count
raft_rcvd_vote [OpenMetrics v1] Number of MsgVote messages received by this store.
Type: float
Unit: count
raft_rcvd_vote_count [OpenMetrics v2] Number of MsgVote messages received by this store.
Type: float
Unit: count
raft_rcvd_voteresp [OpenMetrics v1] Number of MsgVoteResp messages received by this store.
Type: float
Unit: count
raft_rcvd_voteresp_count [OpenMetrics v2] Number of MsgVoteResp messages received by this store.
Type: float
Unit: count
raft_replication_latency_bucket The 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 re_proposals), and application, but notably not sequencing latency (i.e.contention and latch acquisition).
Type: float
Unit: count
raft_replication_latency_count The 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 re_proposals), and application, but notably not sequencing latency (i.e.contention and latch acquisition).
Type: float
Unit: count
raft_replication_latency_sum The 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 re_proposals), and application, but notably not sequencing latency (i.e.contention and latch acquisition).
Type: float
Unit: count
raft_scheduler_latency Queueing 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.
Type: float
Unit: time,ns
raft_scheduler_latency_bucket Queueing 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.
Type: float
Unit: time,ns
raft_scheduler_latency_count Queueing 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.
Type: float
Unit: time,ns
raft_scheduler_latency_sum Queueing 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.
Type: float
Unit: time,ns
raft_sent_bytes Number of bytes in Raft messages sent by this store. Note that this does not include raft snapshot sent.
Type: float
Unit: digital,B
raft_sent_cross_region_bytes Number 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.
Type: float
Unit: digital,B
raft_sent_cross_zone_bytes Number 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.
Type: float
Unit: digital,B
raft_storage_read_bytes Counter of raftpb.Entry.Size() read from pebble for raft log entries.These are the bytes returned from the (raft.Storage).Entries method that were notreturned via the raft entry cache. This metric plus the raft.entrycache.read_bytes metric represent the total bytes returned from the Entries method.
Type: float
Unit: digital,B
raft_ticks [OpenMetrics v1] Number of Raft ticks queued.
Type: float
Unit: count
raft_ticks_count [OpenMetrics v2] Number of Raft ticks queued.
Type: float
Unit: count
raft_timeoutcampaign Number of Raft replicas campaigning after missed heartbeats from leader.
Type: float
Unit: count
raft_transport_flow_token_dispatches_dropped Number of flow token dispatches dropped by the Raft Transport.
Type: float
Unit: count
raft_transport_rcvd Number of Raft messages received by the Raft Transport.
Type: float
Unit: count
raft_transport_reverse_rcvd Messages 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.
Type: float
Unit: count
raft_transport_reverse_sent Messages 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.
Type: float
Unit: count
raft_transport_send_queue_bytes The 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.
Type: float
Unit: digital,B
raft_transport_send_queue_size Number 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.
Type: float
Unit: count
raft_transport_sends_dropped Number of Raft message sends dropped by the Raft Transport.
Type: float
Unit: count
raft_transport_sent Number of Raft messages sent by the Raft Transport.
Type: float
Unit: count
raftlog_behind [OpenMetrics v1 & v2] Number of Raft log entries followers on other stores are behind.
Type: float
Unit: count
raftlog_truncated [OpenMetrics v1] Number of Raft log entries truncated.
Type: float
Unit: count
raftlog_truncated_count [OpenMetrics v2] Number of Raft log entries truncated.
Type: float
Unit: count
range_adds [OpenMetrics v1] Number of range additions.
Type: float
Unit: count
range_adds_count [OpenMetrics v2] Number of range additions.
Type: float
Unit: count
range_merges Number of range merges.
Type: float
Unit: count
range_raftleaderremovals Number of times the current Raft leader was removed from a range.
Type: float
Unit: count
range_raftleadertransfers [OpenMetrics v1] Number of raft leader transfers.
Type: float
Unit: count
range_raftleadertransfers_count [OpenMetrics v2] Number of raft leader transfers.
Type: float
Unit: count
range_recoveries Count 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 replicates located starts following the recovery.
Type: float
Unit: count
range_removes [OpenMetrics v1] Number of range removals.
Type: float
Unit: count
range_removes_count [OpenMetrics v2] Number of range removals.
Type: float
Unit: count
range_snapshots_applied_initial Number of snapshots applied for initial up replication.
Type: float
Unit: count
range_snapshots_applied_non_voter Number of snapshots applied by non-voter replicas.
Type: float
Unit: count
range_snapshots_applied_voter Number of snapshots applied by voter replicas.
Type: float
Unit: count
range_snapshots_cross_region_rcvd_bytes Number of snapshot bytes received cross region.
Type: float
Unit: digital,B
range_snapshots_cross_region_sent_bytes Number of snapshot bytes sent cross region.
Type: float
Unit: digital,B
range_snapshots_cross_zone_rcvd_bytes Number 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.
Type: float
Unit: digital,B
range_snapshots_cross_zone_sent_bytes Number 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.
Type: float
Unit: digital,B
range_snapshots_delegate_failures Number 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 the delegate being too busy to send.
Type: float
Unit: count
range_snapshots_delegate_in_progress Number of delegated snapshots that are currently in-flight.
Type: float
Unit: count
range_snapshots_delegate_sent_bytes Bytes 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 invalidating the network savings of not sending cross region traffic.
Type: float
Unit: digital,B
range_snapshots_delegate_successes Number of snapshots that were delegated to a different node and resulted in success on that delegate. This does not count self delegated snapshots.
Type: float
Unit: count
range_snapshots_generated [OpenMetrics v1] Number of generated snapshots.
Type: float
Unit: count
range_snapshots_generated_count [OpenMetrics v2] Number of generated snapshots.
Type: float
Unit: count
range_snapshots_normal_applied [OpenMetrics v1] Number of applied snapshots.
Type: float
Unit: count
range_snapshots_normal_applied_count [OpenMetrics v2] Number of applied snapshots.
Type: float
Unit: count
range_snapshots_preemptive_applied [OpenMetrics v1] Number of applied pre-emptive snapshots.
Type: float
Unit: count
range_snapshots_preemptive_applied_count [OpenMetrics v2] Number of applied pre-emptive snapshots.
Type: float
Unit: count
range_snapshots_rcvd_bytes Number of snapshot bytes received.
Type: float
Unit: digital,B
range_snapshots_rebalancing_rcvd_bytes Number of rebalancing snapshot bytes received.
Type: float
Unit: digital,B
range_snapshots_rebalancing_sent_bytes Number of rebalancing snapshot bytes sent.
Type: float
Unit: digital,B
range_snapshots_recovery_rcvd_bytes Number of recovery snapshot bytes received.
Type: float
Unit: digital,B
range_snapshots_recovery_sent_bytes Number of recovery snapshot bytes sent.
Type: float
Unit: digital,B
range_snapshots_recv_failed Number of range snapshot initialization messages that errored out on the recipient, typically before any data is transferred.
Type: float
Unit: count
range_snapshots_recv_in_progress Number of non-empty snapshots being received.
Type: float
Unit: count
range_snapshots_recv_queue Number of snapshots queued to receive.
Type: float
Unit: count
range_snapshots_recv_queue_bytes Total size of all snapshots in the snapshot receive queue.
Type: float
Unit: digital,B
range_snapshots_recv_total_in_progress Number of total snapshots being received.
Type: float
Unit: count
range_snapshots_recv_unusable Number of range snapshot that were fully transmitted but determined to be unnecessary or unusable.
Type: float
Unit: count
range_snapshots_send_in_progress Number of non-empty snapshots being sent.
Type: float
Unit: count
range_snapshots_send_queue Number of snapshots queued to send.
Type: float
Unit: count
range_snapshots_send_queue_bytes Total size of all snapshots in the snapshot send queue.
Type: float
Unit: digital,B
range_snapshots_send_total_in_progress Number of total snapshots being sent.
Type: float
Unit: count
range_snapshots_sent_bytes Number of snapshot bytes sent.
Type: float
Unit: digital,B
range_snapshots_unknown_rcvd_bytes Number of unknown snapshot bytes received.
Type: float
Unit: digital,B
range_snapshots_unknown_sent_bytes Number of unknown snapshot bytes sent.
Type: float
Unit: digital,B
range_splits Number of range splits.
Type: float
Unit: count
range_splits_total [OpenMetrics v1] Number of range splits.
Type: float
Unit: count
range_splits_total_count [OpenMetrics v2] Number of range splits.
Type: float
Unit: count
rangekeybytes Number of bytes taken up by range keys (e.g. Multi-Version Concurrency Control range tombstones).
Type: float
Unit: digital,B
rangekeycount Count of all range keys (e.g. Multi-Version Concurrency Control range tombstones).
Type: float
Unit: count
ranges [OpenMetrics v1 & v2] Number of ranges.
Type: float
Unit: count
ranges_overreplicated [OpenMetrics v1 & v2] Number of ranges with more live replicas than the replication target.
Type: float
Unit: count
ranges_unavailable [OpenMetrics v1 & v2] Number of ranges with fewer live replicas than needed for quorum.
Type: float
Unit: count
ranges_underreplicated [OpenMetrics v1 & v2] Number of ranges with fewer live replicas than the replication target.
Type: float
Unit: count
rangevalbytes Number of bytes taken up by range key values (e.g. Multi-Version Concurrency Control range tombstones).
Type: float
Unit: digital,B
rangevalcount Count of all range key values (e.g. Multi-Version Concurrency Control range tombstones).
Type: float
Unit: count
rebalancing_cpunanospersecond Average CPU nanoseconds spent on processing replica operations in the last 30 minutes.
Type: float
Unit: time,ns
rebalancing_lease_transfers Number of lease transfers motivated by store-level load imbalances.
Type: float
Unit: count
rebalancing_queriespersecond Number of kv-level requests received per second by the store, averaged over a large time period as used in rebalancing decisions.
Type: float
Unit: count
rebalancing_range_rebalances Number of range rebalance operations motivated by store-level load imbalances.
Type: float
Unit: count
rebalancing_readbytespersecond Number of bytes read recently per second, considering the last 30 minutes.
Type: float
Unit: digital,B
rebalancing_readspersecond Number of keys read recently per second, considering the last 30 minutes.
Type: float
Unit: count
rebalancing_replicas_cpunanospersecond_bucket Histogram of average CPU nanoseconds spent on processing replica operations in the last 30 minutes.
Type: float
Unit: time,ns
rebalancing_replicas_cpunanospersecond_count Histogram of average CPU nanoseconds spent on processing replica operations in the last 30 minutes.
Type: float
Unit: time,ns
rebalancing_replicas_cpunanospersecond_sum Histogram of average CPU nanoseconds spent on processing replica operations in the last 30 minutes.
Type: float
Unit: time,ns
rebalancing_replicas_queriespersecond_bucket Histogram of average kv-level requests received per second by replicas on the store in the last 30 minutes.
Type: float
Unit: count
rebalancing_replicas_queriespersecond_count Histogram of average kv-level requests received per second by replicas on the store in the last 30 minutes.
Type: float
Unit: count
rebalancing_replicas_queriespersecond_sum Histogram of average kv-level requests received per second by replicas on the store in the last 30 minutes.
Type: float
Unit: count
rebalancing_requestspersecond Number of requests received recently per second, considering the last 30 minutes.
Type: float
Unit: count
rebalancing_state_imbalanced_overfull_options_exhausted Number of occurrences where this store was overfull but failed to shed load after exhausting available rebalance options.
Type: float
Unit: count
rebalancing_writebytespersecond Number of bytes written recently per second, considering the last 30 minutes.
Type: float
Unit: digital,B
rebalancing_writespersecond [OpenMetrics v1 & v2] Number of keys written (i.e. applied by raft) per second to the store, averaged over a large time period as used in rebalancing decisions.
Type: float
Unit: count
replicas Number of replicas.
Type: float
Unit: count
replicas_commandqueue_combinedqueuesize [OpenMetrics v1 & v2] Number of commands in all CommandQueues combined.
Type: float
Unit: count
replicas_commandqueue_combinedreadcount [OpenMetrics v1 & v2] Number of read-only commands in all CommandQueues combined.
Type: float
Unit: count
replicas_commandqueue_combinedwritecount [OpenMetrics v1 & v2] Number of read-write commands in all CommandQueues combined.
Type: float
Unit: count
replicas_commandqueue_maxoverlaps [OpenMetrics v1 & v2] Largest number of overlapping commands seen when adding to any CommandQueue.
Type: float
Unit: count
replicas_commandqueue_maxreadcount [OpenMetrics v1 & v2] Largest number of read-only commands in any CommandQueue.
Type: float
Unit: count
replicas_commandqueue_maxsize [OpenMetrics v1 & v2] Largest number of commands in any CommandQueue.
Type: float
Unit: count
replicas_commandqueue_maxtreesize [OpenMetrics v1 & v2] Largest number of intervals in any CommandQueue's interval tree.
Type: float
Unit: count
replicas_commandqueue_maxwritecount [OpenMetrics v1 & v2] Largest number of read-write commands in any CommandQueue.
Type: float
Unit: count
replicas_leaders [OpenMetrics v1 & v2] Number of raft leaders.
Type: float
Unit: count
replicas_leaders_invalid_lease Number of replicas that are Raft leaders whose lease is invalid.
Type: float
Unit: count
replicas_leaders_not_leaseholders Number of replicas that are Raft leaders whose range lease is held by another store.
Type: float
Unit: count
replicas_leaseholders [OpenMetrics v1 & v2] Number of lease holders.
Type: float
Unit: count
replicas_quiescent [OpenMetrics v1 & v2] Number of quiesced replicas.
Type: float
Unit: count
replicas_reserved [OpenMetrics v1 & v2] Number of replicas reserved for snapshots.
Type: float
Unit: count
replicas_total [OpenMetrics v1 & v2] Number of replicas.
Type: float
Unit: count
replicas_uninitialized Number of uninitialized replicas, this does not include uninitialized replicas that can lie dormant in a persistent state.
Type: float
Unit: count
replication_flush_hist_nanos_count
Type: float
Unit: count
replication_flush_hist_nanos_sum
Type: float
Unit: count
replication_flushes
Type: float
Unit: count
replication_job_progress_updates
Type: float
Unit: count
requests_backpressure_split [OpenMetrics v1 & v2] Number of back pressured writes waiting on a Range split.
Type: float
Unit: count
requests_slow_commandqueue [OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in the command queue.
Type: float
Unit: count
requests_slow_distsender [OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in the dist sender.
Type: float
Unit: count
requests_slow_latch Number of requests that have been stuck for a long time acquiring latches.Latches moderate access to the KV key space 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.
Type: float
Unit: count
requests_slow_lease [OpenMetrics v1 & v2] Number of requests that have been stuck for a long time acquiring a lease.
Type: float
Unit: count
requests_slow_raft [OpenMetrics v1 & v2] Number of requests that have been stuck for a long time in raft.
Type: float
Unit: count
rocksdb_block_cache_hits [OpenMetrics v1 & v2] Count of block cache hits.
Type: float
Unit: count
rocksdb_block_cache_misses [OpenMetrics v1 & v2] Count of block cache misses.
Type: float
Unit: count
rocksdb_block_cache_pinned_usage [OpenMetrics v1 & v2] Bytes pinned by the block cache.
Type: float
Unit: digital,B
rocksdb_block_cache_usage [OpenMetrics v1 & v2] Bytes used by the block cache.
Type: float
Unit: digital,B
rocksdb_bloom_filter_prefix_checked Number of times the bloom filter was checked.
Type: float
Unit: count
rocksdb_bloom_filter_prefix_useful Number of times the bloom filter helped avoid iterator creation.
Type: float
Unit: count
rocksdb_compacted_bytes_read Bytes read during compaction.
Type: float
Unit: digital,B
rocksdb_compacted_bytes_written Bytes written during compaction.
Type: float
Unit: digital,B
rocksdb_compactions Number of table compactions.
Type: float
Unit: count
rocksdb_compactions_total [OpenMetrics v1 & v2] Number of table compactions.
Type: float
Unit: count
rocksdb_encryption_algorithm Algorithm in use for encryption-at-rest, see ccl/storageccl/engineccl/enginepbccl/key_registry.proto.
Type: float
Unit: count
rocksdb_estimated_pending_compaction Estimated pending compaction bytes.
Type: float
Unit: digital,B
rocksdb_flushed_bytes Bytes written during flush.
Type: float
Unit: digital,B
rocksdb_flushes Number of table flushes.
Type: float
Unit: count
rocksdb_flushes_total [OpenMetrics v1 & v2] Number of table flushes.
Type: float
Unit: count
rocksdb_ingested_bytes Bytes ingested.
Type: float
Unit: digital,B
rocksdb_memtable_total_size [OpenMetrics v1 & v2] Current size of mem table in bytes.
Type: float
Unit: digital,B
rocksdb_num_sstables [OpenMetrics v1 & v2] Number of rocks-db SSTables.
Type: float
Unit: count
rocksdb_read_amplification [OpenMetrics v1 & v2] Number of disk reads per query.
Type: float
Unit: count
rocksdb_table_readers_mem_estimate [OpenMetrics v1 & v2] Memory used by index and filter blocks.
Type: float
Unit: count
round_trip_latency [OpenMetrics v1] Distribution of round-trip latencies with other nodes in nanoseconds.
Type: float
Unit: time,ns
round_trip_latency_bucket [OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds.
Type: float
Unit: time,ns
round_trip_latency_count [OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds.
Type: float
Unit: time,ns
round_trip_latency_sum [OpenMetrics v2] Distribution of round-trip latencies with other nodes in nanoseconds.
Type: float
Unit: time,ns
rpc_batches_recv Number of batches processed.
Type: float
Unit: count
rpc_connection_avg_round_trip_latency Sum 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.
Type: float
Unit: time,ns
rpc_connection_failures Counter 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.
Type: float
Unit: count
rpc_connection_healthy Gauge of current connections in a healthy state (i.e. bidirectionally connected and heart beating).
Type: float
Unit: count
rpc_connection_healthy_nanos Gauge of nanoseconds of healthy connection timeOn 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 connected.
Type: float
Unit: time,ns
rpc_connection_heartbeats Counter of successful heartbeats.
Type: float
Unit: count
rpc_connection_inactive Gauge 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 address.
Type: float
Unit: count
rpc_connection_unhealthy Gauge of current connections in an unhealthy state (not bidirectionally connected or heart beating).
Type: float
Unit: count
rpc_connection_unhealthy_nanos Gauge 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 unreachable.
Type: float
Unit: time,ns
rpc_method_addsstable_recv Number of AddSSTable requests processed.
Type: float
Unit: count
rpc_method_adminchangereplicas_recv Number of AdminChangeReplicas requests processed.
Type: float
Unit: count
rpc_method_adminmerge_recv Number of AdminMerge requests processed.
Type: float
Unit: count
rpc_method_adminrelocaterange_recv Number of AdminRelocateRange requests processed.
Type: float
Unit: count
rpc_method_adminscatter_recv Number of AdminScatter requests processed.
Type: float
Unit: count
rpc_method_adminsplit_recv Number of AdminSplit requests processed.
Type: float
Unit: count
rpc_method_admintransferlease_recv Number of AdminTransferLease requests processed.
Type: float
Unit: count
rpc_method_adminunsplit_recv Number of Admin un split requests processed.
Type: float
Unit: count
rpc_method_adminverifyprotectedtimestamp_recv Number of AdminVerifyProtectedTimestamp requests processed.
Type: float
Unit: count
rpc_method_barrier_recv Number of Barrier requests processed.
Type: float
Unit: count
rpc_method_checkconsistency_recv Number of CheckConsistency requests processed.
Type: float
Unit: count
rpc_method_clearrange_recv Number of ClearRange requests processed.
Type: float
Unit: count
rpc_method_computechecksum_recv Number of ComputeChecksum requests processed.
Type: float
Unit: count
rpc_method_conditionalput_recv Number of ConditionalPut requests processed.
Type: float
Unit: count
rpc_method_delete_recv Number of Delete requests processed.
Type: float
Unit: count
rpc_method_deleterange_recv Number of DeleteRange requests processed.
Type: float
Unit: count
rpc_method_endtxn_recv Number of EndTxn requests processed.
Type: float
Unit: count
rpc_method_export_recv Number of Export requests processed.
Type: float
Unit: count
rpc_method_gc_recv Number of GC requests processed.
Type: float
Unit: count
rpc_method_get_recv Number of Get requests processed.
Type: float
Unit: count
rpc_method_heartbeattxn_recv Number of HeartbeatTxn requests processed.
Type: float
Unit: count
rpc_method_increment_recv Number of Increment requests processed.
Type: float
Unit: count
rpc_method_initput_recv Number of InitPut requests processed.
Type: float
Unit: count
rpc_method_isspanempty_recv Number of IsSpanEmpty requests processed.
Type: float
Unit: count
rpc_method_leaseinfo_recv Number of LeaseInfo requests processed.
Type: float
Unit: count
rpc_method_merge_recv Number of Merge requests processed.
Type: float
Unit: count
rpc_method_migrate_recv Number of Migrate requests processed.
Type: float
Unit: count
rpc_method_probe_recv Number of Probe requests processed.
Type: float
Unit: count
rpc_method_pushtxn_recv Number of PushTxn requests processed.
Type: float
Unit: count
rpc_method_put_recv Number of Put requests processed.
Type: float
Unit: count
rpc_method_queryintent_recv Number of QueryIntent requests processed.
Type: float
Unit: count
rpc_method_querylocks_recv Number of QueryLocks requests processed.
Type: float
Unit: count
rpc_method_queryresolvedtimestamp_recv Number of QueryResolvedTimestamp requests processed.
Type: float
Unit: count
rpc_method_querytxn_recv Number of QueryTxn requests processed.
Type: float
Unit: count
rpc_method_rangestats_recv Number of RangeStats requests processed.
Type: float
Unit: count
rpc_method_recomputestats_recv Number of RecomputeStats requests processed.
Type: float
Unit: count
rpc_method_recovertxn_recv Number of RecoverTxn requests processed.
Type: float
Unit: count
rpc_method_refresh_recv Number of Refresh requests processed.
Type: float
Unit: count
rpc_method_refreshrange_recv Number of RefreshRange requests processed.
Type: float
Unit: count
rpc_method_requestlease_recv Number of RequestLease requests processed.
Type: float
Unit: count
rpc_method_resolveintent_recv Number of ResolveIntent requests processed.
Type: float
Unit: count
rpc_method_resolveintentrange_recv Number of ResolveIntentRange requests processed.
Type: float
Unit: count
rpc_method_reversescan_recv Number of ReverseScan requests processed.
Type: float
Unit: count
rpc_method_revertrange_recv Number of RevertRange requests processed.
Type: float
Unit: count
rpc_method_scan_recv Number of Scan requests processed.
Type: float
Unit: count
rpc_method_subsume_recv Number of Subsume requests processed.
Type: float
Unit: count
rpc_method_transferlease_recv Number of TransferLease requests processed.
Type: float
Unit: count
rpc_method_truncatelog_recv Number of TruncateLog requests processed.
Type: float
Unit: count
rpc_method_writebatch_recv Number of WriteBatch requests processed.
Type: float
Unit: count
rpc_streams_mux_rangefeed_active Number of currently running MuxRangeFeed streams.
Type: float
Unit: count
rpc_streams_mux_rangefeed_recv Total number of MuxRangeFeed streams.
Type: float
Unit: count
rpc_streams_rangefeed_active Number of currently running RangeFeed streams.
Type: float
Unit: count
rpc_streams_rangefeed_recv Total number of RangeFeed streams.
Type: float
Unit: count
schedules_BACKUP_failed Number of BACKUP jobs failed.
Type: float
Unit: count
schedules_BACKUP_last_completed_time The unix timestamp of the most recently completed backup by a schedule specified as maintaining this metric.
Type: float
Unit: count
schedules_BACKUP_protected_age_sec The age of the oldest PTS record protected by BACKUP schedules.
Type: float
Unit: time,s
schedules_BACKUP_protected_record_count Number of PTS records held by BACKUP schedules.
Type: float
Unit: count
schedules_BACKUP_started Number of BACKUP jobs started.
Type: float
Unit: count
schedules_BACKUP_succeeded Number of BACKUP jobs succeeded.
Type: float
Unit: count
schedules_CHANGEFEED_failed Number of CHANGE FEED jobs failed.
Type: float
Unit: count
schedules_CHANGEFEED_started Number of CHANGE FEED jobs started.
Type: float
Unit: count
schedules_CHANGEFEED_succeeded Number of CHANGE FEED jobs succeeded.
Type: float
Unit: count
schedules_backup_failed [OpenMetrics v1] Number of scheduled backup jobs failed.
Type: float
Unit: count
schedules_backup_failed_count [OpenMetrics v2] Number of scheduled backup jobs failed.
Type: float
Unit: count
schedules_backup_last_completed_time [OpenMetrics v1 & v2] The unix timestamp of the most recently completed backup by a schedule specified as maintaining this metric.
Type: float
Unit: time,s
schedules_backup_started [OpenMetrics v1] Number of scheduled backup jobs started.
Type: float
Unit: count
schedules_backup_started_count [OpenMetrics v2] Number of scheduled backup jobs started.
Type: float
Unit: count
schedules_backup_succeeded [OpenMetrics v1] Number of scheduled backup jobs succeeded.
Type: float
Unit: count
schedules_backup_succeeded_count [OpenMetrics v2] Number of scheduled backup jobs succeeded.
Type: float
Unit: count
schedules_error Number of schedules which did not execute successfully.
Type: float
Unit: count
schedules_malformed Number of malformed schedules.
Type: float
Unit: count
schedules_round_jobs_started The number of jobs started.
Type: float
Unit: count
schedules_round_reschedule_skip The number of schedules rescheduled due to SKIP policy.
Type: float
Unit: count
schedules_round_reschedule_wait The number of schedules rescheduled due to WAIT policy.
Type: float
Unit: count
schedules_scheduled_row_level_ttl_executor_failed Number of scheduled-row-level-ttl-executor jobs failed.
Type: float
Unit: count
schedules_scheduled_row_level_ttl_executor_started Number of scheduled-row-level-ttl-executor jobs started.
Type: float
Unit: count
schedules_scheduled_row_level_ttl_executor_succeeded Number of scheduled-row-level-ttl-executor jobs succeeded.
Type: float
Unit: count
schedules_scheduled_schema_telemetry_executor_failed Number of scheduled-schema-telemetry-executor jobs failed.
Type: float
Unit: count
schedules_scheduled_schema_telemetry_executor_started Number of scheduled-schema-telemetry-executor jobs started.
Type: float
Unit: count
schedules_scheduled_schema_telemetry_executor_succeeded Number of scheduled-schema-telemetry-executor jobs succeeded.
Type: float
Unit: count
schedules_scheduled_sql_stats_compaction_executor_failed Number of scheduled-sql-stats-compaction-executor jobs failed.
Type: float
Unit: count
schedules_scheduled_sql_stats_compaction_executor_started Number of scheduled-sql-stats-compaction-executor jobs started.
Type: float
Unit: count
schedules_scheduled_sql_stats_compaction_executor_succeeded Number of scheduled-sql-stats-compaction-executor jobs succeeded.
Type: float
Unit: count
seconds_until_enterprise_license_expiry Seconds until enterprise license expiry (0 if no license present or running without enterprise features).
Type: float
Unit: count
security_certificate_expiration_ca Expiration for the CA certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_ca_client_tenant Expiration for the Tenant Client CA certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_client Minimum expiration for client certificates, labeled by SQL user. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_client_ca Expiration for the client CA certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_client_tenant Expiration for the Tenant Client certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_node Expiration for the node certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_node_client Expiration for the node's client certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_ui Expiration for the UI certificate. 0 means no certificate or error.
Type: float
Unit: count
security_certificate_expiration_ui_ca Expiration for the UI CA certificate. 0 means no certificate or error.
Type: float
Unit: count
spanconfig_kvsubscriber_oldest_protected_record_nanos Difference 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).
Type: float
Unit: time,ns
spanconfig_kvsubscriber_protected_record_count Number of protected timestamp records, as seen by KV.
Type: float
Unit: count
spanconfig_kvsubscriber_update_behind_nanos Difference between the current time and when the KVSubscriber received its last update (an ever increasing number indicates that we're no longer receiving updates).
Type: float
Unit: time,ns
sql_bytesin [OpenMetrics v1] Number of SQL bytes received.
Type: float
Unit: digital,B
sql_bytesin_count [OpenMetrics v2] Number of SQL bytes received.
Type: float
Unit: digital,B
sql_bytesout [OpenMetrics v1] Number of SQL bytes sent.
Type: float
Unit: digital,B
sql_bytesout_count [OpenMetrics v2] Number of SQL bytes sent.
Type: float
Unit: digital,B
sql_conn_failures Number of SQL connection failures.
Type: float
Unit: count
sql_conn_latency [OpenMetrics v1] Latency to establish and authenticate a SQL connection.
Type: float
Unit: time,ns
sql_conn_latency_bucket [OpenMetrics v2] Latency to establish and authenticate a SQL connection.
Type: float
Unit: time,ns
sql_conn_latency_count [OpenMetrics v2] Latency to establish and authenticate a SQL connection.
Type: float
Unit: time,ns
sql_conn_latency_sum [OpenMetrics v2] Latency to establish and authenticate a SQL connection.
Type: float
Unit: time,ns
sql_conns [OpenMetrics v1 & v2] Number of active SQL connections.
Type: float
Unit: count
sql_conns_waiting_to_hash Number of SQL connection attempts that are being throttled in order to limit password hashing concurrency.
Type: float
Unit: count
sql_contention_resolver_failed_resolutions Number of failed transaction ID resolution attempts.
Type: float
Unit: count
sql_contention_resolver_queue_size Length of queued unresolved contention events.
Type: float
Unit: count
sql_contention_resolver_retries Number of times transaction id resolution has been retried.
Type: float
Unit: count
sql_contention_txn_id_cache_miss Number of cache misses.
Type: float
Unit: count
sql_contention_txn_id_cache_read Number of cache read.
Type: float
Unit: count
sql_copy_count Number of COPY SQL statements successfully executed.
Type: float
Unit: count
sql_copy_internal Number of COPY SQL statements successfully executed (internal queries).
Type: float
Unit: count
sql_copy_nonatomic_count Number of non-atomic COPY SQL statements successfully executed.
Type: float
Unit: count
sql_copy_nonatomic_count_internal
Type: float
Unit: count
sql_copy_nonatomic_internal Number of non-atomic COPY SQL statements successfully executed (internal queries).
Type: float
Unit: count
sql_copy_nonatomic_started_count Number of non-atomic COPY SQL statements started.
Type: float
Unit: count
sql_copy_nonatomic_started_internal Number of non-atomic COPY SQL statements started (internal queries).
Type: float
Unit: count
sql_copy_started_count Number of COPY SQL statements started.
Type: float
Unit: count
sql_copy_started_internal Number of COPY SQL statements started (internal queries).
Type: float
Unit: count
sql_ddl_count [OpenMetrics v1 & v2] Number of SQL DDL statements.
Type: float
Unit: count
sql_ddl_internal Number of SQL DDL statements successfully executed (internal queries).
Type: float
Unit: count
sql_ddl_started Number of SQL DDL statements started.
Type: float
Unit: count
sql_ddl_started_count Number of SQL DELETE statements started.
Type: float
Unit: count
sql_ddl_started_internal Number of SQL DDL statements started (internal queries).
Type: float
Unit: count
sql_delete_count [OpenMetrics v1 & v2] Number of SQL DELETE statements.
Type: float
Unit: count
sql_delete_internal Number of SQL DELETE statements successfully executed (internal queries).
Type: float
Unit: count
sql_delete_started_count Number of SQL DELETE statements started (internal queries).
Type: float
Unit: count
sql_delete_started_internal Number of SQL DELETE statements started (internal queries).
Type: float
Unit: count
sql_disk_distsql_current Current SQL statement disk usage for distributed SQL.
Type: float
Unit: digital,B
sql_disk_distsql_max_bucket Disk usage per SQL statement for distributed SQL.
Type: float
Unit: digital,B
sql_disk_distsql_max_count Disk usage per SQL statement for distributed SQL.
Type: float
Unit: digital,B
sql_disk_distsql_max_sum Disk usage per SQL statement for distributed SQL.
Type: float
Unit: digital,B
sql_disk_distsql_spilled_bytes_read Number of bytes read from temporary disk storage as a result of spilling.
Type: float
Unit: digital,B
sql_disk_distsql_spilled_bytes_written Number of bytes written to temporary disk storage as a result of spilling.
Type: float
Unit: digital,B
sql_distsql_contended_queries [OpenMetrics v1] Number of SQL queries that experienced contention.
Type: float
Unit: count
sql_distsql_contended_queries_count [OpenMetrics v2] Number of SQL queries that experienced contention0.
Type: float
Unit: count
sql_distsql_dist_query_rerun_locally Total number of cases when distributed query error resulted in a local rerun.
Type: float
Unit: count
sql_distsql_dist_query_rerun_locally_failure_count Total number of cases when the local rerun of a distributed query resulted in an error.
Type: float
Unit: count
sql_distsql_exec_latency [OpenMetrics v1] Latency in nanoseconds of DistSQL statement execution.
Type: float
Unit: time,ns
sql_distsql_exec_latency_bucket Latency of DistSQL statement execution.
Type: float
Unit: time,ns
sql_distsql_exec_latency_count [OpenMetrics v2] Latency in nanoseconds of DistSQL statement execution.
Type: float
Unit: time,ns
sql_distsql_exec_latency_internal_bucket Latency of DistSQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_exec_latency_internal_count Latency of DistSQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_exec_latency_internal_sum Latency of DistSQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_exec_latency_sum [OpenMetrics v2] Latency in nanoseconds of DistSQL statement execution.
Type: float
Unit: time,ns
sql_distsql_flows [OpenMetrics v2] Number of distributed SQL flows executed.
Type: float
Unit: count
sql_distsql_flows_active [OpenMetrics v1 & v2] Number of distributed SQL flows currently active.
Type: float
Unit: count
sql_distsql_flows_total [OpenMetrics v1] Number of distributed SQL flows executed.
Type: float
Unit: count
sql_distsql_flows_total_count Number of distributed SQL flows executed.
Type: float
Unit: count
sql_distsql_queries [OpenMetrics v2] Number of distributed SQL queries executed.
Type: float
Unit: count
sql_distsql_queries_active [OpenMetrics v1 & v2] Number of distributed SQL queries currently active.
Type: float
Unit: count
sql_distsql_queries_spilled Number of queries that have spilled to disk.
Type: float
Unit: count
sql_distsql_queries_total [OpenMetrics v1] Number of distributed SQL queries executed.
Type: float
Unit: count
sql_distsql_select [OpenMetrics v1 & v2] Number of DistSQL SELECT statements.
Type: float
Unit: count
sql_distsql_select_internal Number of DistSQL SELECT statements (internal queries).
Type: float
Unit: count
sql_distsql_service_latency [OpenMetrics v1] Latency in nanoseconds of DistSQL request execution.
Type: float
Unit: time,ns
sql_distsql_service_latency_bucket [OpenMetrics v2] Latency in nanoseconds of DistSQL request execution.
Type: float
Unit: time,ns
sql_distsql_service_latency_count [OpenMetrics v2] Latency in nanoseconds of DistSQL request execution.
Type: float
Unit: time,ns
sql_distsql_service_latency_internal Latency of DistSQL request execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_service_latency_internal_bucket Latency of DistSQL request execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_service_latency_internal_count Latency of DistSQL request execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_service_latency_internal_sum Latency of DistSQL request execution (internal queries).
Type: float
Unit: time,ns
sql_distsql_service_latency_sum [OpenMetrics v2] Latency in nanoseconds of DistSQL request execution.
Type: float
Unit: time,ns
sql_distsql_vec_openfds Current number of open file descriptors used by vectorized external storage.
Type: float
Unit: count
sql_exec_latency [OpenMetrics v1] Latency in nanoseconds of SQL statement execution.
Type: float
Unit: time,ns
sql_exec_latency_bucket [OpenMetrics v2] Latency in nanoseconds of SQL statement execution.
Type: float
Unit: time,ns
sql_exec_latency_count [OpenMetrics v2] Latency in nanoseconds of SQL statement execution.
Type: float
Unit: time,ns
sql_exec_latency_internal Latency of SQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_exec_latency_internal_bucket Latency of SQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_exec_latency_internal_count Latency of SQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_exec_latency_internal_sum Latency of SQL statement execution (internal queries).
Type: float
Unit: time,ns
sql_exec_latency_sum [OpenMetrics v2] Latency in nanoseconds of SQL statement execution.
Type: float
Unit: time,ns
sql_failure [OpenMetrics v1] Number of statements resulting in a planning or runtime error.
Type: float
Unit: count
sql_failure_count [OpenMetrics v2] Number of statements resulting in a planning or runtime error.
Type: float
Unit: count
sql_failure_internal Number of statements resulting in a planning or runtime error (internal queries).
Type: float
Unit: count
sql_feature_flag_denial Counter of the number of statements denied by a feature flag.
Type: float
Unit: count
sql_full_scan [OpenMetrics v1] Number of full table or index scans.
Type: float
Unit: count
sql_full_scan_count [OpenMetrics v2] Number of full table or index scans.
Type: float
Unit: count
sql_full_scan_internal Number of full table or index scans (internal queries).
Type: float
Unit: count
sql_guardrails_full_scan_rejected Number of full table or index scans that have been rejected because of disallow_full_table_scans guardrail.
Type: float
Unit: count
sql_guardrails_full_scan_rejected_internal Number of full table or index scans that have been rejected because of disallow_full_table_scans guardrail (internal queries).
Type: float
Unit: count
sql_guardrails_max_row_size_err Number of rows observed violating sql.guardrails.maxrowsize_err.
Type: float
Unit: count
sql_guardrails_max_row_size_err_internal Number of rows observed violating sql.guardrails.maxrowsize_err (internal queries).
Type: float
Unit: count
sql_guardrails_max_row_size_log Number of rows observed violating sql.guardrails.maxrowsize_log.
Type: float
Unit: count
sql_guardrails_max_row_size_log_internal Number of rows observed violating sql.guardrails.maxrowsize_log (internal queries).
Type: float
Unit: count
sql_guardrails_transaction_rows_read_err Number of transactions errored because of transactionrowsread_err guardrail.
Type: float
Unit: count
sql_guardrails_transaction_rows_read_err_internal Number of transactions errored because of transactionrowsread_err guardrail (internal queries).
Type: float
Unit: count
sql_guardrails_transaction_rows_read_log Number of transactions logged because of transactionrowsread_log guardrail.
Type: float
Unit: count
sql_guardrails_transaction_rows_read_log_internal Number of transactions logged because of transactionrowsread_log guardrail (internal queries).
Type: float
Unit: count
sql_guardrails_transaction_rows_written_err Number of transactions errored because of transactionrowswritten_err guardrail.
Type: float
Unit: count
sql_guardrails_transaction_rows_written_err_internal Number of transactions errored because of transactionrowswritten_err guardrail (internal queries).
Type: float
Unit: count
sql_guardrails_transaction_rows_written_log Number of transactions logged because of transactionrowswritten_log guardrail.
Type: float
Unit: count
sql_guardrails_transaction_rows_written_log_internal Number of transactions logged because of transactionrowswritten_log guardrail (internal queries).
Type: float
Unit: count
sql_hydrated_schema_cache_hits counter on the number of cache hits.
Type: float
Unit: count
sql_hydrated_schema_cache_misses counter on the number of cache misses.
Type: float
Unit: count
sql_hydrated_table_cache_hits counter on the number of cache hits.
Type: float
Unit: count
sql_hydrated_table_cache_misses counter on the number of cache misses.
Type: float
Unit: count
sql_hydrated_type_cache_hits counter on the number of cache hits.
Type: float
Unit: count
sql_hydrated_type_cache_misses counter on the number of cache misses.
Type: float
Unit: count
sql_hydrated_udf_cache_hits counter on the number of cache hits.
Type: float
Unit: count
sql_hydrated_udf_cache_misses counter on the number of cache misses.
Type: float
Unit: count
sql_insert [OpenMetrics v1 & v2] Number of SQL INSERT statements.
Type: float
Unit: count
sql_insert_internal Number of SQL INSERT statements successfully executed (internal queries).
Type: float
Unit: count
sql_insert_started Number of SQL INSERT statements started.
Type: float
Unit: count
sql_insert_started_internal Number of SQL INSERT statements started (internal queries).
Type: float
Unit: count
sql_insights_anomaly_detection_evictions Evictions of fingerprint latency summaries due to memory pressure.
Type: float
Unit: count
sql_insights_anomaly_detection_fingerprints Current number of statement fingerprints being monitored for anomaly detection.
Type: float
Unit: count
sql_insights_anomaly_detection_memory Current memory used to support anomaly detection.
Type: float
Unit: digital,B
sql_leases_active The number of outstanding SQL schema leases.
Type: float
Unit: count
sql_mem_admin_current [OpenMetrics v1 & v2] Current SQL statement memory usage for admin.
Type: float
Unit: count
sql_mem_admin_max [OpenMetrics v1] Memory usage per SQL statement for admin.
Type: float
Unit: count
sql_mem_admin_max_bucket [OpenMetrics v2] Memory usage per SQL statement for admin.
Type: float
Unit: count
sql_mem_admin_max_count [OpenMetrics v2] Memory usage per SQL statement for admin.
Type: float
Unit: count
sql_mem_admin_max_sum [OpenMetrics v2] Memory usage per SQL statement for admin.
Type: float
Unit: count
sql_mem_admin_session_current [OpenMetrics v1 & v2] Current SQL session memory usage for admin.
Type: float
Unit: count
sql_mem_admin_session_max_bucket [OpenMetrics v2] Memory usage per SQL session for admin.
Type: float
Unit: count
sql_mem_admin_session_max_count [OpenMetrics v2] Memory usage per SQL session for admin.
Type: float
Unit: count
sql_mem_admin_session_max_sum [OpenMetrics v2] Memory usage per SQL session for admin.
Type: float
Unit: count
sql_mem_admin_txn_current [OpenMetrics v1 & v2] Current SQL transaction memory usage for admin.
Type: float
Unit: count
sql_mem_admin_txn_max [OpenMetrics v1] Memory usage per SQL transaction for admin.
Type: float
Unit: count
sql_mem_admin_txn_max_bucket [OpenMetrics v2] Memory usage per SQL transaction for admin.
Type: float
Unit: count
sql_mem_admin_txn_max_count [OpenMetrics v2] Memory usage per SQL transaction for admin.
Type: float
Unit: count
sql_mem_admin_txn_max_sum [OpenMetrics v2] Memory usage per SQL transaction for admin.
Type: float
Unit: count
sql_mem_bulk_current Current SQL statement memory usage for bulk operations.
Type: float
Unit: digital,B
sql_mem_bulk_max Memory usage per SQL statement for bulk operations.
Type: float
Unit: digital,B
sql_mem_bulk_max_bucket Memory usage per SQL statement for bulk operations.
Type: float
Unit: digital,B
sql_mem_bulk_max_count Memory usage per SQL statement for bulk operations.
Type: float
Unit: digital,B
sql_mem_bulk_max_sum Memory usage per SQL statement for bulk operations.
Type: float
Unit: digital,B
sql_mem_client_current [OpenMetrics v1 & v2] Current SQL statement memory usage for client.
Type: float
Unit: count
sql_mem_client_max [OpenMetrics v1] Memory usage per SQL statement for client.
Type: float
Unit: count
sql_mem_client_max_bucket [OpenMetrics v2] Memory usage per SQL statement for client.
Type: float
Unit: count
sql_mem_client_max_count [OpenMetrics v2] Memory usage per SQL statement for client.
Type: float
Unit: count
sql_mem_client_max_sum [OpenMetrics v2] Memory usage per SQL statement for client.
Type: float
Unit: count
sql_mem_client_session_current [OpenMetrics v1 & v2] Current SQL session memory usage for client.
Type: float
Unit: count
sql_mem_client_session_max [OpenMetrics v1] Memory usage per SQL session for client.
Type: float
Unit: count
sql_mem_client_session_max_bucket [OpenMetrics v2] Memory usage per SQL session for client.
Type: float
Unit: count
sql_mem_client_session_max_count [OpenMetrics v2] Memory usage per SQL session for client.
Type: float
Unit: count
sql_mem_client_session_max_sum [OpenMetrics v2] Memory usage per SQL session for client.
Type: float
Unit: count
sql_mem_client_txn_current [OpenMetrics v1 & v2] Current SQL transaction memory usage for client.
Type: float
Unit: count
sql_mem_client_txn_max [OpenMetrics v1] Memory usage per SQL transaction for client.
Type: float
Unit: count
sql_mem_client_txn_max_bucket [OpenMetrics v2] Memory usage per SQL transaction for client.
Type: float
Unit: count
sql_mem_client_txn_max_count [OpenMetrics v2] Memory usage per SQL transaction for client.
Type: float
Unit: count
sql_mem_client_txn_max_sum [OpenMetrics v2] Memory usage per SQL transaction for client.
Type: float
Unit: count
sql_mem_conns_current [OpenMetrics v1 & v2] Current SQL statement memory usage for conns.
Type: float
Unit: count
sql_mem_conns_max [OpenMetrics v1] Memory usage per SQL statement for conns.
Type: float
Unit: count
sql_mem_conns_max_bucket [OpenMetrics v2] Memory usage per SQL statement for conns.
Type: float
Unit: count
sql_mem_conns_max_count [OpenMetrics v2] Memory usage per SQL statement for conns.
Type: float
Unit: count
sql_mem_conns_max_sum [OpenMetrics v2] Memory usage per SQL statement for conns.
Type: float
Unit: count
sql_mem_conns_session_current [OpenMetrics v1 & v2] Current SQL session memory usage for conns.
Type: float
Unit: count
sql_mem_conns_session_max [OpenMetrics v1] Memory usage per SQL session for conns.
Type: float
Unit: count
sql_mem_conns_session_max_bucket [OpenMetrics v2] Memory usage per SQL session for conns.
Type: float
Unit: count
sql_mem_conns_session_max_count [OpenMetrics v2] Memory usage per SQL session for conns.
Type: float
Unit: count
sql_mem_conns_session_max_sum [OpenMetrics v2] Memory usage per SQL session for conns.
Type: float
Unit: count
sql_mem_conns_txn_current [OpenMetrics v1 & v2] Current SQL transaction memory usage for conns.
Type: float
Unit: count
sql_mem_conns_txn_max [OpenMetrics v1] Memory usage per SQL transaction for conns.
Type: float
Unit: count
sql_mem_conns_txn_max_bucket [OpenMetrics v2] Memory usage per SQL transaction for conns.
Type: float
Unit: count
sql_mem_conns_txn_max_count [OpenMetrics v2] Memory usage per SQL transaction for conns.
Type: float
Unit: count
sql_mem_conns_txn_max_sum [OpenMetrics v2] Memory usage per SQL transaction for conns.
Type: float
Unit: count
sql_mem_distsql_current [OpenMetrics v1 & v2] Current SQL statement memory usage for distributed SQL.
Type: float
Unit: count
sql_mem_distsql_max [OpenMetrics v1] Memory usage per SQL statement for distributed SQL.
Type: float
Unit: count
sql_mem_distsql_max_bucket [OpenMetrics v2] Memory usage per SQL statement for distributed SQL.
Type: float
Unit: count
sql_mem_distsql_max_count [OpenMetrics v2] Memory usage per SQL statement for distributed SQL.
Type: float
Unit: count
sql_mem_distsql_max_sum [OpenMetrics v2] Memory usage per SQL statement for distributed SQL.
Type: float
Unit: count
sql_mem_internal_current [OpenMetrics v1 & v2] Current SQL statement memory usage for internal.
Type: float
Unit: count
sql_mem_internal_max [OpenMetrics v1] Memory usage per SQL statement for internal.
Type: float
Unit: count
sql_mem_internal_max_bucket [OpenMetrics v2] Memory usage per SQL statement for internal.
Type: float
Unit: count
sql_mem_internal_max_count [OpenMetrics v2] Memory usage per SQL statement for internal.
Type: float
Unit: count
sql_mem_internal_max_sum [OpenMetrics v2] Memory usage per SQL statement for internal.
Type: float
Unit: count
sql_mem_internal_session_current [OpenMetrics v1 & v2] Current SQL session memory usage for internal.
Type: float
Unit: count
sql_mem_internal_session_max [OpenMetrics v1] Memory usage per SQL session for internal.
Type: float
Unit: count
sql_mem_internal_session_max_bucket [OpenMetrics v2] Memory usage per SQL session for internal.
Type: float
Unit: count
sql_mem_internal_session_max_count [OpenMetrics v2] Memory usage per SQL session for internal.
Type: float
Unit: count
sql_mem_internal_session_max_sum [OpenMetrics v2] Memory usage per SQL session for internal.
Type: float
Unit: count
sql_mem_internal_session_prepared_current Current SQL session memory usage by prepared statements for internal.
Type: float
Unit: digital,B
sql_mem_internal_session_prepared_max_bucket Memory usage by prepared statements per SQL session for internal.
Type: float
Unit: digital,B
sql_mem_internal_session_prepared_max_count Memory usage by prepared statements per SQL session for internal.
Type: float
Unit: digital,B
sql_mem_internal_session_prepared_max_sum Memory usage by prepared statements per SQL session for internal.
Type: float
Unit: digital,B
sql_mem_internal_txn_current [OpenMetrics v1 & v2] Current SQL transaction memory usage for internal.
Type: float
Unit: count
sql_mem_internal_txn_max [OpenMetrics v1] Memory usage per SQL transaction for internal.
Type: float
Unit: count
sql_mem_internal_txn_max_bucket [OpenMetrics v2] Memory usage per SQL transaction for internal.
Type: float
Unit: count
sql_mem_internal_txn_max_count [OpenMetrics v2] Memory usage per SQL transaction for internal.
Type: float
Unit: count
sql_mem_internal_txn_max_sum [OpenMetrics v2] Memory usage per SQL transaction for internal.
Type: float
Unit: count
sql_mem_root_current Current SQL statement memory usage for root.
Type: float
Unit: count
sql_mem_root_max_bucket Memory usage per SQL statement for root.
Type: float
Unit: digital,B
sql_mem_root_max_count Memory usage per SQL statement for root.
Type: float
Unit: digital,B
sql_mem_root_max_sum Memory usage per SQL statement for root.
Type: float
Unit: digital,B
sql_mem_sql_current Current SQL statement memory usage for SQL.
Type: float
Unit: digital,B
sql_mem_sql_max Memory usage per SQL statement for SQL.
Type: float
Unit: digital,B
sql_mem_sql_max_bucket Memory usage per SQL statement for SQL.
Type: float
Unit: digital,B
sql_mem_sql_max_count Memory usage per SQL statement for SQL.
Type: float
Unit: digital,B
sql_mem_sql_max_sum Memory usage per SQL statement for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_current Current SQL session memory usage for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_max Memory usage per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_max_bucket Memory usage per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_max_count Memory usage per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_max_sum Memory usage per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_prepared_current Current SQL session memory usage by prepared statements for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_prepared_max Memory usage by prepared statements per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_prepared_max_bucket Memory usage by prepared statements per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_prepared_max_count Memory usage by prepared statements per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_session_prepared_max_sum Memory usage by prepared statements per SQL session for SQL.
Type: float
Unit: digital,B
sql_mem_sql_txn_current Current SQL transaction memory usage for SQL.
Type: float
Unit: digital,B
sql_mem_sql_txn_max Memory usage per SQL transaction for SQL.
Type: float
Unit: digital,B
sql_mem_sql_txn_max_bucket Memory usage per SQL transaction for SQL.
Type: float
Unit: digital,B
sql_mem_sql_txn_max_count Memory usage per SQL transaction for SQL.
Type: float
Unit: digital,B
sql_mem_sql_txn_max_sum Memory usage per SQL transaction for SQL.
Type: float
Unit: digital,B
sql_misc [OpenMetrics v1 & v2] Number of other SQL statements.
Type: float
Unit: count
sql_misc_internal Number of other SQL statements successfully executed (internal queries).
Type: float
Unit: count
sql_misc_started Number of other SQL statements started.
Type: float
Unit: count
sql_misc_started_internal Number of other SQL statements started (internal queries).
Type: float
Unit: count
sql_new_conns Counter of the number of SQL connections created.
Type: float
Unit: count
sql_optimizer_fallback Number of statements which the cost-based optimizer was unable to plan.
Type: float
Unit: count
sql_optimizer_fallback_internal Number of statements which the cost-based optimizer was unable to plan (internal queries).
Type: float
Unit: count
sql_optimizer_plan_cache_hits Number of non-prepared statements for which a cached plan was used.
Type: float
Unit: count
sql_optimizer_plan_cache_hits_internal Number of non-prepared statements for which a cached plan was used (internal queries).
Type: float
Unit: count
sql_optimizer_plan_cache_misses Number of non-prepared statements for which a cached plan was not used.
Type: float
Unit: count
sql_optimizer_plan_cache_misses_internal Number of non-prepared statements for which a cached plan was not used (internal queries).
Type: float
Unit: count
sql_pgwire_cancel Number of PostgreSQL Wire Protocol query cancel requests.
Type: float
Unit: count
sql_pgwire_cancel_ignored Number of PostgreSQL Wire Protocol query cancel requests that were ignored due to rate limiting.
Type: float
Unit: count
sql_pgwire_cancel_successful Number of PostgreSQL Wire Protocol query cancel requests that were successful.
Type: float
Unit: count
sql_pre_serve_bytesin Number of SQL bytes received prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_bytesout Number of SQL bytes sent prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_conn_failures Number of SQL connection failures prior to routing the connection to the target SQL server.
Type: float
Unit: count
sql_pre_serve_mem_cur Current memory usage for SQL connections prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_mem_max Memory usage for SQL connections prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_mem_max_bucket Memory usage for SQL connections prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_mem_max_count Memory usage for SQL connections prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_mem_max_sum Memory usage for SQL connections prior to routing the connection to the target SQL server.
Type: float
Unit: digital,B
sql_pre_serve_new_conns Number of SQL connections created prior to routing the connection to the target SQL server.
Type: float
Unit: count
sql_query [OpenMetrics v1 & v2] Number of SQL queries.
Type: float
Unit: count
sql_query_internal Number of SQL queries executed (internal queries).
Type: float
Unit: count
sql_query_started Number of SQL queries started.
Type: float
Unit: count
sql_query_started_internal Number of SQL queries started (internal queries).
Type: float
Unit: count
sql_restart_savepoint Number of SAVE POINT cockroach_restart statements successfully executed.
Type: float
Unit: count
sql_restart_savepoint_internal Number of SAVE POINT cockroach_restart statements successfully executed (internal queries).
Type: float
Unit: count
sql_restart_savepoint_release Number of RELEASE SAVE POINT cockroach_restart statements successfully executed.
Type: float
Unit: count
sql_restart_savepoint_release_internal Number of RELEASE SAVE POINT cockroach_restart statements successfully executed (internal queries).
Type: float
Unit: count
sql_restart_savepoint_release_started Number of RELEASE SAVE POINT cockroach_restart statements started.
Type: float
Unit: count
sql_restart_savepoint_release_started_internal Number of RELEASE SAVE POINT cockroach_restart statements started (internal queries).
Type: float
Unit: count
sql_restart_savepoint_rollback Number of ROLLBACK TO SAVE POINT cockroach_restart statements successfully executed.
Type: float
Unit: count
sql_restart_savepoint_rollback_internal Number of ROLLBACK TO SAVE POINT cockroach_restart statements successfully executed (internal queries).
Type: float
Unit: count
sql_restart_savepoint_rollback_started Number of ROLLBACK TO SAVE POINT cockroach_restart statements started.
Type: float
Unit: count
sql_restart_savepoint_rollback_started_internal Number of ROLLBACK TO SAVE POINT cockroach_restart statements started (internal queries).
Type: float
Unit: count
sql_restart_savepoint_started Number of SAVE POINT cockroach_restart statements started.
Type: float
Unit: count
sql_restart_savepoint_started_internal Number of SAVE POINT cockroach_restart statements started (internal queries).
Type: float
Unit: count
sql_savepoint Number of SQL SAVE POINT statements successfully executed.
Type: float
Unit: count
sql_savepoint_internal Number of SQL SAVE POINT statements successfully executed (internal queries).
Type: float
Unit: count
sql_savepoint_release Number of RELEASE SAVE POINT statements successfully executed.
Type: float
Unit: count
sql_savepoint_release_internal Number of RELEASE SAVE POINT statements successfully executed (internal queries).
Type: float
Unit: count
sql_savepoint_release_started Number of RELEASE SAVE POINT statements started.
Type: float
Unit: count
sql_savepoint_release_started_internal Number of RELEASE SAVE POINT statements started (internal queries).
Type: float
Unit: count
sql_savepoint_rollback Number of ROLLBACK TO SAVE POINT statements successfully executed.
Type: float
Unit: count
sql_savepoint_rollback_internal Number of ROLLBACK TO SAVE POINT statements successfully executed (internal queries).
Type: float
Unit: count
sql_savepoint_rollback_started Number of ROLLBACK TO SAVE POINT statements started.
Type: float
Unit: count
sql_savepoint_rollback_started_internal Number of ROLLBACK TO SAVE POINT statements started (internal queries).
Type: float
Unit: count
sql_savepoint_started Number of SQL SAVE POINT statements started.
Type: float
Unit: count
sql_savepoint_started_internal Number of SQL SAVE POINT statements started (internal queries).
Type: float
Unit: count
sql_schema_changer_permanent_errors Counter of the number of permanent errors experienced by the schema changer.
Type: float
Unit: count
sql_schema_changer_retry_errors Counter of the number of retry able errors experienced by the schema changer.
Type: float
Unit: count
sql_schema_changer_running Gauge of currently running schema changes.
Type: float
Unit: count
sql_schema_changer_successes Counter of the number of schema changer resumes which succeed.
Type: float
Unit: count
sql_schema_invalid_objects Gauge of detected invalid objects within the system.descriptor table (measured by querying crdbinternal.invalid objects).
Type: float
Unit: count
sql_select [OpenMetrics v1 & v2] Number of SQL SELECT statements.
Type: float
Unit: count
sql_select_internal Number of SQL SELECT statements successfully executed (internal queries).
Type: float
Unit: count
sql_select_started Number of SQL SELECT statements started.
Type: float
Unit: count
sql_select_started_internal Number of SQL SELECT statements started (internal queries).
Type: float
Unit: count
sql_service_latency [OpenMetrics v1] Latency in nanoseconds of SQL request execution.
Type: float
Unit: time,ns
sql_service_latency_bucket [OpenMetrics v2] Latency in nanoseconds of SQL request execution.
Type: float
Unit: time,ns
sql_service_latency_count [OpenMetrics v2] Latency in nanoseconds of SQL request execution.
Type: float
Unit: time,ns
sql_service_latency_internal Latency of SQL request execution (internal queries).
Type: float
Unit: time,ns
sql_service_latency_internal_bucket Latency of SQL request execution (internal queries).
Type: float
Unit: time,ns
sql_service_latency_internal_count Latency of SQL request execution (internal queries).
Type: float
Unit: time,ns
sql_service_latency_internal_sum Latency of SQL request execution (internal queries).
Type: float
Unit: time,ns
sql_service_latency_sum [OpenMetrics v2] Latency in nanoseconds of SQL request execution.
Type: float
Unit: time,ns
sql_statements_active [OpenMetrics v1 & v2] Number of currently active user SQL statements.
Type: float
Unit: count
sql_statements_active_internal Number of currently active user SQL statements (internal queries).
Type: float
Unit: count
sql_stats_cleanup_rows_removed Number of stale statistics rows that are removed.
Type: float
Unit: count
sql_stats_discarded_current Number of fingerprint statistics being discarded.
Type: float
Unit: count
sql_stats_flush Number of times SQL Stats are flushed to persistent storage.
Type: float
Unit: count
sql_stats_flush_duration Time took to in nanoseconds to complete SQL Stats flush.
Type: float
Unit: time,ns
sql_stats_flush_duration_bucket Time took to in nanoseconds to complete SQL Stats flush.
Type: float
Unit: time,ns
sql_stats_flush_duration_count Time took to in nanoseconds to complete SQL Stats flush.
Type: float
Unit: time,ns
sql_stats_flush_duration_sum Time took to in nanoseconds to complete SQL Stats flush.
Type: float
Unit: time,ns
sql_stats_flush_error Number of errors encountered when flushing SQL Stats.
Type: float
Unit: count
sql_stats_mem_current Current memory usage for fingerprint storage.
Type: float
Unit: digital,B
sql_stats_mem_max Memory usage for fingerprint storage.
Type: float
Unit: digital,B
sql_stats_mem_max_bucket Memory usage for fingerprint storage.
Type: float
Unit: digital,B
sql_stats_mem_max_count Memory usage for fingerprint storage.
Type: float
Unit: digital,B
sql_stats_mem_max_sum Memory usage for fingerprint storage.
Type: float
Unit: digital,B
sql_stats_reported_mem_current Current memory usage for reported fingerprint storage.
Type: float
Unit: digital,B
sql_stats_reported_mem_max Memory usage for reported fingerprint storage.
Type: float
Unit: digital,B
sql_stats_reported_mem_max_bucket Memory usage for reported fingerprint storage.
Type: float
Unit: digital,B
sql_stats_reported_mem_max_count Memory usage for reported fingerprint storage.
Type: float
Unit: digital,B
sql_stats_reported_mem_max_sum Memory usage for reported fingerprint storage.
Type: float
Unit: digital,B
sql_stats_txn_stats_collection_duration Time took in nanoseconds to collect transaction stats.
Type: float
Unit: time,ns
sql_stats_txn_stats_collection_duration_bucket Time took in nanoseconds to collect transaction stats.
Type: float
Unit: time,ns
sql_stats_txn_stats_collection_duration_count Time took in nanoseconds to collect transaction stats.
Type: float
Unit: time,ns
sql_stats_txn_stats_collection_duration_sum Time took in nanoseconds to collect transaction stats.
Type: float
Unit: time,ns
sql_temp_object_cleaner_active_cleaners number of cleaner tasks currently running on this node.
Type: float
Unit: count
sql_temp_object_cleaner_schemas_deletion_error number of errored schema deletions by the temp object cleaner on this node.
Type: float
Unit: count
sql_temp_object_cleaner_schemas_deletion_success number of successful schema deletions by the temp object cleaner on this node.
Type: float
Unit: count
sql_temp_object_cleaner_schemas_to_delete number of schemas to be deleted by the temp object cleaner on this node.
Type: float
Unit: count
sql_txn_abort [OpenMetrics v1 & v2] Number of SQL transaction ABORT statements.
Type: float
Unit: count
sql_txn_abort_internal Number of SQL transaction abort errors (internal queries).
Type: float
Unit: count
sql_txn_begin [OpenMetrics v1 & v2] Number of SQL transaction BEGIN statements.
Type: float
Unit: count
sql_txn_begin_internal Number of SQL transaction BEGIN statements successfully executed (internal queries).
Type: float
Unit: count
sql_txn_begin_started Number of SQL transaction BEGIN statements started.
Type: float
Unit: count
sql_txn_begin_started_internal Number of SQL transaction BEGIN statements started (internal queries).
Type: float
Unit: count
sql_txn_commit [OpenMetrics v1 & v2] Number of SQL transaction COMMIT statements.
Type: float
Unit: count
sql_txn_commit_internal Number of SQL transaction COMMIT statements successfully executed (internal queries).
Type: float
Unit: count
sql_txn_commit_started Number of SQL transaction COMMIT statements started.
Type: float
Unit: count
sql_txn_commit_started_internal Number of SQL transaction COMMIT statements started (internal queries).
Type: float
Unit: count
sql_txn_contended Number of SQL transactions experienced contention.
Type: float
Unit: count
sql_txn_contended_internal Number of SQL transactions experienced contention (internal queries).
Type: float
Unit: count
sql_txn_latency [OpenMetrics v1] Latency of SQL transactions.
Type: float
Unit: percent,percent
sql_txn_latency_bucket [OpenMetrics v2] Latency of SQL transactions.
Type: float
Unit: time,ns
sql_txn_latency_count [OpenMetrics v2] Latency of SQL transactions.
Type: float
Unit: percent,percent
sql_txn_latency_internal_bucket Latency of SQL transactions (internal queries).
Type: float
Unit: time,ns
sql_txn_latency_internal_count Latency of SQL transactions (internal queries).
Type: float
Unit: time,ns
sql_txn_latency_internal_sum Latency of SQL transactions (internal queries).
Type: float
Unit: time,ns
sql_txn_latency_sum [OpenMetrics v2] Latency of SQL transactions.
Type: float
Unit: percent,percent
sql_txn_rollback [OpenMetrics v1 & v2] Number of SQL transaction ROLLBACK statements.
Type: float
Unit: count
sql_txn_rollback_internal Number of SQL transaction ROLLBACK statements successfully executed (internal queries).
Type: float
Unit: count
sql_txn_rollback_started Number of SQL transaction ROLLBACK statements started.
Type: float
Unit: count
sql_txn_rollback_started_internal Number of SQL transaction ROLLBACK statements started (internal queries).
Type: float
Unit: count
sql_txns_open [OpenMetrics v1 & v2] Number of currently open user SQL transactions.
Type: float
Unit: percent,percent
sql_txns_open_internal Number of currently open user SQL transactions (internal queries).
Type: float
Unit: count
sql_update [OpenMetrics v1 & v2] Number of SQL UPDATE statements.
Type: float
Unit: count
sql_update_internal Number of SQL UPDATE statements successfully executed (internal queries).
Type: float
Unit: count
sql_update_started Number of SQL UPDATE statements started.
Type: float
Unit: count
sql_update_started_internal Number of SQL UPDATE statements started (internal queries).
Type: float
Unit: count
sqlliveness_is_alive_cache_hits Number of calls to IsAlive that return from the cache.
Type: float
Unit: count
sqlliveness_is_alive_cache_misses Number of calls to IsAlive that do not return from the cache.
Type: float
Unit: count
sqlliveness_sessions_deleted Number of expired sessions which have been deleted.
Type: float
Unit: count
sqlliveness_sessions_deletion_runs Number of calls to delete sessions which have been performed.
Type: float
Unit: count
sqlliveness_write_failures Number of update or insert calls which have failed.
Type: float
Unit: count
sqlliveness_write_successes Number of update or insert calls successfully performed.
Type: float
Unit: count
storage_batch_commit Count of batch commits. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: count
storage_batch_commit_commit_wait_duration Cumulative time spent waiting for WAL sync, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_duration Cumulative time spent in batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_l0_stall_duration Cumulative time spent in a write stall due to high read amplification in L0, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_mem_stall_duration Cumulative time spent in a write stall due to too many mem tables, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_sem_wait_duration Cumulative time spent in semaphore wait, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_wal_queue_wait_duration Cumulative time spent waiting for memory blocks in the WAL queue, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_batch_commit_wal_rotation_duration Cumulative time spent waiting for WAL rotation, for batch commit. See storage.AggregatedBatchCommitStats for details.
Type: float
Unit: time,ns
storage_checkpoints The 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.
Type: float
Unit: count
storage_compactions_duration Cumulative 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.
Type: float
Unit: time,ns
storage_compactions_keys_pinned Cumulative 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.
Type: float
Unit: count
storage_compactions_keys_pinned_bytes Cumulative 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.
Type: float
Unit: digital,B
storage_disk_slow Number of instances of disk operations taking longer than 10s.
Type: float
Unit: count
storage_disk_stalled Number of instances of disk operations taking longer than 20s.
Type: float
Unit: count
storage_flush_ingest Flushes performing an ingest (flushable ingestion).
Type: float
Unit: count
storage_flush_ingest_table Tables ingested via flushes (flushable ingestion).
Type: float
Unit: count
storage_flush_ingest_table_bytes Bytes ingested via flushes (flushable ingestion).
Type: float
Unit: digital,B
storage_flush_utilization The percentage of time the storage engine is actively flushing mem tables to disk.
Type: float
Unit: percent,percent
storage_ingest Number of successful ingestion performed.
Type: float
Unit: count
storage_iterator_block_load_bytes Bytes loaded by storage engine iterators (possibly cached). See storage.AggregatedIteratorStats for details.
Type: float
Unit: digital,B
storage_iterator_block_load_cached_bytes Bytes loaded by storage engine iterators from the block cache. See storage.AggregatedIteratorStats for details.
Type: float
Unit: digital,B
storage_iterator_block_load_read_duration Cumulative time storage engine iterators spent loading blocks from durable storage. See storage.AggregatedIteratorStats for details.
Type: float
Unit: time,ns
storage_iterator_external_seeks Cumulative count of seeks performed on storage engine iterators. See storage.AggregatedIteratorStats for details.
Type: float
Unit: count
storage_iterator_external_steps Cumulative count of steps performed on storage engine iterators. See storage.AggregatedIteratorStats for details.
Type: float
Unit: count
storage_iterator_internal_seeks Cumulative 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.
Type: float
Unit: count
storage_iterator_internal_steps Cumulative 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.
Type: float
Unit: count
storage_keys_range_key_set Approximate count of RangeKeySet internal keys across the storage engine.
Type: float
Unit: count
storage_keys_tombstone Approximate count of DEL, SINGLE DEL and RANGE DEL internal keys across the storage engine.
Type: float
Unit: count
storage_l0_bytes_flushed Number of bytes flushed (from mem tables) into Level 0.
Type: float
Unit: digital,B
storage_l0_bytes_ingested Number of bytes ingested directly into Level 0.
Type: float
Unit: digital,B
storage_l0_level_score Compaction score of level 0.
Type: float
Unit: count
storage_l0_level_size Size of the SSTables in level 0.
Type: float
Unit: digital,B
storage_l0_num_files Number of SSTables in Level 0.
Type: float
Unit: count
storage_l0_sublevels Number of Level 0 sublevels.
Type: float
Unit: count
storage_l1_bytes_ingested Number of bytes ingested directly into Level 1.
Type: float
Unit: digital,B
storage_l1_level_score Compaction score of level 1.
Type: float
Unit: count
storage_l1_level_size Size of the SSTables in level 1.
Type: float
Unit: digital,B
storage_l2_bytes_ingested Number of bytes ingested directly into Level 2.
Type: float
Unit: digital,B
storage_l2_level_score Compaction score of level 2.
Type: float
Unit: count
storage_l2_level_size Size of the SSTables in level 2.
Type: float
Unit: digital,B
storage_l3_bytes_ingested Number of bytes ingested directly into Level 3.
Type: float
Unit: digital,B
storage_l3_level_score Compaction score of level 3.
Type: float
Unit: count
storage_l3_level_size Size of the SSTables in level 3.
Type: float
Unit: digital,B
storage_l4_bytes_ingested Number of bytes ingested directly into Level 4.
Type: float
Unit: digital,B
storage_l4_level_score Compaction score of level 4.
Type: float
Unit: count
storage_l4_level_size Size of the SSTables in level 4.
Type: float
Unit: digital,B
storage_l5_bytes_ingested Number of bytes ingested directly into Level 5.
Type: float
Unit: digital,B
storage_l5_level_score Compaction score of level 5.
Type: float
Unit: count
storage_l5_level_size Size of the SSTables in level 5.
Type: float
Unit: digital,B
storage_l6_bytes_ingested Number of bytes ingested directly into Level 6.
Type: float
Unit: digital,B
storage_l6_level_score Compaction score of level 6.
Type: float
Unit: count
storage_l6_level_size Size of the SSTables in level 6.
Type: float
Unit: digital,B
storage_marked_for_compaction_files Count of SSTables marked for compaction.
Type: float
Unit: count
storage_queue_store_failures Number of replicas which failed processing in replica queues due to retry able store errors.
Type: float
Unit: count
storage_secondary_cache The count of cache blocks in the secondary cache (not SSTable blocks).
Type: float
Unit: count
storage_secondary_cache_evictions The number of times a cache block was evicted from the secondary cache.
Type: float
Unit: count
storage_secondary_cache_reads_full_hit The number of reads where all data returned was read from the secondary cache.
Type: float
Unit: count
storage_secondary_cache_reads_multi_block The number of secondary cache reads that require reading data from 2+ cache blocks.
Type: float
Unit: count
storage_secondary_cache_reads_multi_shard The number of secondary cache reads that require reading data from 2+ shards.
Type: float
Unit: count
storage_secondary_cache_reads_no_hit The number of reads where no data returned was read from the secondary cache.
Type: float
Unit: count
storage_secondary_cache_reads_partial_hit The number of reads where some data returned was read from the secondary cache.
Type: float
Unit: count
storage_secondary_cache_reads_total The number of reads from the secondary cache.
Type: float
Unit: count
storage_secondary_cache_size The number of SSTable bytes stored in the secondary cache.
Type: float
Unit: digital,B
storage_secondary_cache_write_back_failures The number of times writing a cache block to the secondary cache failed.
Type: float
Unit: count
storage_shared_storage_read Bytes read from shared storage.
Type: float
Unit: digital,B
storage_shared_storage_write Bytes written to external storage.
Type: float
Unit: digital,B
storage_single_delete_ineffectual Number of SingleDeletes that were ineffectual.
Type: float
Unit: count
storage_single_delete_invariant_violation Number of SingleDelete invariant violations.
Type: float
Unit: count
storage_wal_bytes_in The number of logical bytes the storage engine has written to the WAL.
Type: float
Unit: count
storage_wal_bytes_written The number of bytes the storage engine has written to the WAL.
Type: float
Unit: count
storage_wal_fsync_latency_bucket The write ahead log fsync latency.
Type: float
Unit: time,ns
storage_wal_fsync_latency_count The write ahead log fsync latency.
Type: float
Unit: time,ns
storage_wal_fsync_latency_sum The write ahead log fsync latency.
Type: float
Unit: time,ns
storage_write_stall_nanos Total write stall duration in nanosecond.
Type: float
Unit: time,ns
storage_write_stalls Number of instances of intentional write stalls to back pressure incoming writes.
Type: float
Unit: count
sys_cgo_allocbytes [OpenMetrics v1 & v2] Current bytes of memory allocated by cgo.
Type: float
Unit: digital,B
sys_cgo_totalbytes [OpenMetrics v1 & v2] Total bytes of memory allocated by cgo, but not released.
Type: float
Unit: digital,B
sys_cgocalls [OpenMetrics v1 & v2] Total number of cgo calls.
Type: float
Unit: count
sys_cpu_combined_percent_normalized [OpenMetrics v1 & v2] Current user+system cpu percentage, normalized 0-1 by number of cores.
Type: float
Unit: percent,percent
sys_cpu_host_combined_percent_normalized Current user+system cpu percentage across the whole machine, normalized 0-1 by number of cores.
Type: float
Unit: percent,percent
sys_cpu_now_ns The time when CPU measurements were taken, as nanoseconds since epoch.
Type: float
Unit: time,ns
sys_cpu_sys_ns [OpenMetrics v1 & v2] Total system cpu time in nanoseconds.
Type: float
Unit: time,ns
sys_cpu_sys_percent [OpenMetrics v1 & v2] Current system cpu percentage.
Type: float
Unit: percent,percent
sys_cpu_user_ns [OpenMetrics v1 & v2] Total user cpu time in nanoseconds.
Type: float
Unit: time,ns
sys_cpu_user_percent [OpenMetrics v1 & v2] Current user cpu percentage.
Type: float
Unit: percent,percent
sys_fd_open [OpenMetrics v1 & v2] Process open file descriptors.
Type: float
Unit: count
sys_fd_softlimit [OpenMetrics v1 & v2] Process open FD soft limit.
Type: float
Unit: count
sys_gc [OpenMetrics v2] Total number of GC runs.
Type: float
Unit: count
sys_gc_count [OpenMetrics v1] Total number of GC runs.
Type: float
Unit: count
sys_gc_pause_ns [OpenMetrics v1 & v2] Total GC pause in nanoseconds.
Type: float
Unit: time,ns
sys_gc_pause_percent [OpenMetrics v1 & v2] Current GC pause percentage.
Type: float
Unit: percent,percent
sys_go_allocbytes [OpenMetrics v1 & v2] Current bytes of memory allocated by go.
Type: float
Unit: digital,B
sys_go_totalbytes [OpenMetrics v1 & v2] Total bytes of memory allocated by go, but not released.
Type: float
Unit: digital,B
sys_goroutines [OpenMetrics v1 & v2] Current number of goroutines.
Type: float
Unit: count
sys_host_disk_io_time Time spent reading from or writing to all disks since this process started.
Type: float
Unit: time,ns
sys_host_disk_iopsinprogress IO operations currently in progress on this host.
Type: float
Unit: count
sys_host_disk_read Disk read operations across all disks since this process started.
Type: float
Unit: count
sys_host_disk_read_bytes [OpenMetrics v1 & v2] Bytes read from all disks since this process started.
Type: float
Unit: digital,B
sys_host_disk_read_count Disk read operations across all disks since this process started.
Type: float
Unit: count
sys_host_disk_read_time Time spent reading from all disks since this process started.
Type: float
Unit: time,ns
sys_host_disk_weightedio_time Weighted time spent reading from or writing to to all disks since this process started.
Type: float
Unit: time,ns
sys_host_disk_write Disk write operations across all disks since this process started.
Type: float
Unit: count
sys_host_disk_write_bytes [OpenMetrics v1 & v2] Bytes written to all disks since this process started.
Type: float
Unit: digital,B
sys_host_disk_write_count Disk write operations across all disks since this process started.
Type: float
Unit: count
sys_host_disk_write_time Time spent writing to all disks since this process started.
Type: float
Unit: time,ns
sys_host_net_recv_bytes [OpenMetrics v1 & v2] Bytes received on all network interfaces since this process started.
Type: float
Unit: digital,B
sys_host_net_recv_packets Packets received on all network interfaces since this process started.
Type: float
Unit: count
sys_host_net_send_bytes [OpenMetrics v1 & v2] Bytes sent on all network interfaces since this process started.
Type: float
Unit: digital,B
sys_host_net_send_packets Packets sent on all network interfaces since this process started.
Type: float
Unit: count
sys_rss [OpenMetrics v1 & v2] Memory Usage (Bytes).
Type: float
Unit: digital,B
sys_runnable_goroutines_per_cpu Average number of goroutines that are waiting to run, normalized by number of cores.
Type: float
Unit: count
sys_totalmem Total memory (both free and used).
Type: float
Unit: digital,B
sys_uptime [OpenMetrics v1 & v2] Process uptime in seconds.
Type: float
Unit: time,s
sysbytes [OpenMetrics v1 & v2] Number of bytes in system KV pairs.
Type: float
Unit: digital,B
syscount [OpenMetrics v1 & v2] Count of system KV pairs.
Type: float
Unit: count
tenant_consumption_cross_region_network_ru Total number of RUs charged for cross-region network traffic.
Type: float
Unit: count
tenant_consumption_external_io_egress_bytes Total number of bytes written to external services such as cloud storage providers.
Type: float
Unit: count
tenant_consumption_external_io_ingress_bytes Total number of bytes read from external services such as cloud storage providers.
Type: float
Unit: count
tenant_consumption_kv_request_units RU consumption attributable to KV.
Type: float
Unit: count
tenant_consumption_kv_request_units_count RU consumption attributable to KV.
Type: float
Unit: count
tenant_consumption_pgwire_egress_bytes Total number of bytes transferred from a SQL pod to the client.
Type: float
Unit: count
tenant_consumption_read_batches Total number of KV read batches.
Type: float
Unit: count
tenant_consumption_read_bytes Total number of bytes read from KV.
Type: float
Unit: count
tenant_consumption_read_requests Total number of KV read requests.
Type: float
Unit: count
tenant_consumption_request_units Total RU consumption.
Type: float
Unit: count
tenant_consumption_request_units_count Total RU consumption.
Type: float
Unit: count
tenant_consumption_sql_pods_cpu_seconds Total amount of CPU used by SQL pods.
Type: float
Unit: time,s
tenant_consumption_write_batches Total number of KV write batches.
Type: float
Unit: count
tenant_consumption_write_bytes Total number of bytes written to KV.
Type: float
Unit: count
tenant_consumption_write_requests Total number of KV write requests.
Type: float
Unit: count
timeseries_write_bytes [OpenMetrics v1] Total size in bytes of metric samples written to disk.
Type: float
Unit: digital,B
timeseries_write_bytes_count [OpenMetrics v2] Total size in bytes of metric samples written to disk.
Type: float
Unit: digital,B
timeseries_write_errors [OpenMetrics v1] Total errors encountered while attempting to write metrics to disk.
Type: float
Unit: count
timeseries_write_errors_count [OpenMetrics v2] Total errors encountered while attempting to write metrics to disk.
Type: float
Unit: count
timeseries_write_samples [OpenMetrics v1] Total number of metric samples written to disk.
Type: float
Unit: count
timeseries_write_samples_count [OpenMetrics v2] Total number of metric samples written to disk.
Type: float
Unit: count
totalbytes [OpenMetrics v1 & v2] Total number of bytes taken up by keys and values including non-live data.
Type: float
Unit: digital,B
tscache_skl_pages Number of pages in the timestamp cache.
Type: float
Unit: count
tscache_skl_read_pages [OpenMetrics v1 & v2] Number of pages in the read timestamp cache.
Type: float
Unit: count
tscache_skl_read_rotations [OpenMetrics v1] Number of page rotations in the read timestamp cache.
Type: float
Unit: count
tscache_skl_read_rotations_count [OpenMetrics v2] Number of page rotations in the read timestamp cache.
Type: float
Unit: count
tscache_skl_rotations Number of page rotations in the timestamp cache.
Type: float
Unit: count
tscache_skl_write_pages [OpenMetrics v1 & v2] Number of pages in the write timestamp cache.
Type: float
Unit: count
tscache_skl_write_rotations [OpenMetrics v1] Number of page rotations in the write timestamp cache.
Type: float
Unit: count
tscache_skl_write_rotations_count [OpenMetrics v2] Number of page rotations in the write timestamp cache.
Type: float
Unit: count
txn_abandons [OpenMetrics v1] Number of abandoned KV transactions.
Type: float
Unit: count
txn_abandons_count [OpenMetrics v2] Number of abandoned KV transactions.
Type: float
Unit: count
txn_aborts [OpenMetrics v1] Number of aborted KV transactions.
Type: float
Unit: count
txn_aborts_count [OpenMetrics v2] Number of aborted KV transactions.
Type: float
Unit: count
txn_autoretries [OpenMetrics v1] Number of automatic retries to avoid serializable restarts.
Type: float
Unit: count
txn_autoretries_count [OpenMetrics v2] Number of automatic retries to avoid serializable restarts.
Type: float
Unit: count
txn_commit_waits Number of KV transactions that had to commit-wait on commit in order to ensure line serialization. This generally happens to transactions writing to global ranges.
Type: float
Unit: count
txn_commit_waits_before_commit_trigger Number of KV transactions that had to commit-wait on the server before committing because they had a commit trigger.
Type: float
Unit: count
txn_commits [OpenMetrics v1] Number of committed KV transactions (including 1PC).
Type: float
Unit: count
txn_commits1PC [OpenMetrics v1] Number of committed one-phase KV transactions.
Type: float
Unit: count
txn_commits1PC_count [OpenMetrics v2] Number of committed one-phase KV transactions.
Type: float
Unit: count
txn_commits_count [OpenMetrics v2] Number of committed KV transactions (including 1PC).
Type: float
Unit: count
txn_condensed_intent_spans KV transactions that have exceeded their intent tracking memory budget (kv.transaction.maxintentsbytes). See also txn.condensedintentspans_gauge for a gauge of such transactions currently running.
Type: float
Unit: count
txn_condensed_intent_spans_gauge KV transactions currently running that have exceeded their intent tracking memory budget (kv.transaction.maxintentsbytes). See also txn.condensedintentspans for a perpetual counter/rate.
Type: float
Unit: count
txn_condensed_intent_spans_rejected KV transactions that have been aborted because they exceeded their intent tracking memory budget (kv.transaction.maxintentsbytes). Rejection is caused by kv.transaction.rejectovermaxintentsbudget.
Type: float
Unit: count
txn_durations [OpenMetrics v1] KV transaction durations in nanoseconds.
Type: float
Unit: count
txn_durations_bucket [OpenMetrics v2] KV transaction durations in nanoseconds.
Type: float
Unit: count
txn_durations_count [OpenMetrics v2] KV transaction durations in nanoseconds.
Type: float
Unit: count
txn_durations_sum [OpenMetrics v2] KV transaction durations in nanoseconds.
Type: float
Unit: count
txn_parallelcommits Number of KV transaction parallel commit attempts.
Type: float
Unit: count
txn_parallelcommits_auto_retries Number of commit tries after successful failed parallel commit attempts.
Type: float
Unit: count
txn_refresh_auto_retries Number of request retries after successful client-side refreshes.
Type: float
Unit: count
txn_refresh_fail Number of failed client-side transaction refreshes.
Type: float
Unit: count
txn_refresh_fail_with_condensed_spans Number 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.memorylimitexceeded.
Type: float
Unit: count
txn_refresh_memory_limit_exceeded Number of transaction which exceed the refresh span bytes limit, causing their read spans to be condensed.
Type: float
Unit: count
txn_refresh_success Number 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.
Type: float
Unit: count
txn_refresh_success_server_side Number of successful server-side transaction refreshes.
Type: float
Unit: count
txn_restarts [OpenMetrics v1] Number of restarted KV transactions.
Type: float
Unit: count
txn_restarts_asyncwritefailure Number of restarts due to async consensus writes that failed to leave intents.
Type: float
Unit: count
txn_restarts_bucket [OpenMetrics v2] Number of restarted KV transactions.
Type: float
Unit: count
txn_restarts_commitdeadlineexceeded Number of restarts due to a transaction exceeding its deadline.
Type: float
Unit: count
txn_restarts_count [OpenMetrics v2] Number of restarted KV transactions.
Type: float
Unit: count
txn_restarts_deleterange [OpenMetrics v1] Number of restarts due to a forwarded commit timestamp and a DeleteRange command.
Type: float
Unit: count
txn_restarts_deleterange_count [OpenMetrics v2] Number of restarts due to a forwarded commit timestamp and a DeleteRange command.
Type: float
Unit: count
txn_restarts_possiblereplay [OpenMetrics v1] Number of restarts due to possible replays of command batches at the storage layer.
Type: float
Unit: count
txn_restarts_possiblereplay_count [OpenMetrics v2] Number of restarts due to possible replays of command batches at the storage layer.
Type: float
Unit: count
txn_restarts_readwithinuncertainty Number of restarts due to reading a new value within the uncertainty interval.
Type: float
Unit: count
txn_restarts_serializable [OpenMetrics v1] Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE.
Type: float
Unit: count
txn_restarts_serializable_count [OpenMetrics v2] Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE.
Type: float
Unit: count
txn_restarts_sum [OpenMetrics v2] Number of restarted KV transactions.
Type: float
Unit: count
txn_restarts_txnaborted Number of restarts due to an abort by a concurrent transaction (usually due to deadlock).
Type: float
Unit: count
txn_restarts_txnpush Number of restarts due to a transaction push failure.
Type: float
Unit: count
txn_restarts_unknown Number of restarts due to a unknown reasons.
Type: float
Unit: count
txn_restarts_writetooold [OpenMetrics v1] Number of restarts due to a concurrent writer committing first.
Type: float
Unit: count
txn_restarts_writetooold_count [OpenMetrics v2] Number of restarts due to a concurrent writer committing first.
Type: float
Unit: count
txn_restarts_writetoooldmulti Number of restarts due to multiple concurrent writers committing first.
Type: float
Unit: count
txn_rollbacks_async_failed Number of KV transaction that failed to send abort asynchronously which is not always retried.
Type: float
Unit: count
txn_rollbacks_failed Number of KV transaction that failed to send final abort.
Type: float
Unit: count
txn_server_side_1PC_failure Number of batches that attempted to commit using 1PC and failed.
Type: float
Unit: count
txn_server_side_1PC_success Number of batches that attempted to commit using 1PC and succeeded.
Type: float
Unit: count
txn_server_side_retry_read_evaluation_failure Number of read batches that were not successfully refreshed server side.
Type: float
Unit: count
txn_server_side_retry_read_evaluation_success Number of read batches that were successfully refreshed server side.
Type: float
Unit: count
txn_server_side_retry_uncertainty_interval_error_failure Number of batches that ran into uncertainty interval errors that were not successfully refreshed server side.
Type: float
Unit: count
txn_server_side_retry_uncertainty_interval_error_success Number of batches that ran into uncertainty interval errors that were successfully refreshed server side.
Type: float
Unit: count
txn_server_side_retry_write_evaluation_failure Number of write batches that were not successfully refreshed server side.
Type: float
Unit: count
txn_server_side_retry_write_evaluation_success Number of write batches that were successfully refreshed server side.
Type: float
Unit: count
txnrecovery_attempts Number of transaction recovery attempts executed.
Type: float
Unit: count
txnrecovery_attempts_pending Number of transaction recovery attempts currently in-flight.
Type: float
Unit: count
txnrecovery_failures Number of transaction recovery attempts that failed.
Type: float
Unit: count
txnrecovery_successes_aborted Number of transaction recovery attempts that aborted a transaction.
Type: float
Unit: count
txnrecovery_successes_committed Number of transaction recovery attempts that committed a transaction.
Type: float
Unit: count
txnrecovery_successes_pending Number of transaction recovery attempts that left a transaction pending.
Type: float
Unit: count
txnwaitqueue_deadlocks Number of deadlocks detected by the txn wait queue.
Type: float
Unit: count
txnwaitqueue_deadlocks_total Number of deadlocks detected by the txn wait queue.
Type: float
Unit: count
txnwaitqueue_pushee_waiting Number of pushers on the txn wait queue.
Type: float
Unit: count
txnwaitqueue_pusher_slow The total number of cases where a pusher waited more than the excessive wait threshold.
Type: float
Unit: count
txnwaitqueue_pusher_wait_time_bucket Histogram of durations spent in queue by pushers.
Type: float
Unit: time,ns
txnwaitqueue_pusher_wait_time_count Histogram of durations spent in queue by pushers.
Type: float
Unit: time,ns
txnwaitqueue_pusher_wait_time_sum Histogram of durations spent in queue by pushers.
Type: float
Unit: time,ns
txnwaitqueue_pusher_waiting Number of pushers on the txn wait queue.
Type: float
Unit: count
txnwaitqueue_query_wait_time_bucket Histogram of durations spent in queue by queries.
Type: float
Unit: time,ns
txnwaitqueue_query_wait_time_count Histogram of durations spent in queue by queries.
Type: float
Unit: time,ns
txnwaitqueue_query_wait_time_sum Histogram of durations spent in queue by queries.
Type: float
Unit: time,ns
txnwaitqueue_query_waiting Number of transaction status queries waiting for an updated transaction record.
Type: float
Unit: count
valbytes [OpenMetrics v1 & v2] Number of bytes taken up by values.
Type: float
Unit: digital,B
valcount [OpenMetrics v1 & v2] Count of all values.
Type: float
Unit: count

文档评价

文档内容是否对您有帮助? ×