Skip to content

Commit

Permalink
Merge branch 'main' into v25.1.0-beta.2
Browse files Browse the repository at this point in the history
  • Loading branch information
mikeCRL authored Jan 27, 2025
2 parents ff63f2d + a48d77a commit 10bb275
Show file tree
Hide file tree
Showing 26 changed files with 8,439 additions and 22 deletions.
File renamed without changes.
2,594 changes: 2,594 additions & 0 deletions src/current/_data/v24.2/metrics/metrics-list.csv

Large diffs are not rendered by default.

File renamed without changes.
477 changes: 477 additions & 0 deletions src/current/_data/v24.3/metrics/available-metrics-in-metrics-list.csv

Large diffs are not rendered by default.

Original file line number Diff line number Diff line change
@@ -0,0 +1,19 @@
metric_id,description,y-axis label,type,unit
"security.certificate.expiration.ca","Expiration for the CA certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.client-ca","Expiration for the client CA certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.client","Minimum expiration for client certificates, labeled by SQL user. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.ui-ca","Expiration for the UI CA certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.node","Expiration for the node certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.node-client","Expiration for the node's client certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.ui","Expiration for the UI certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.ca-client-tenant","Expiration for the Tenant Client CA certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.expiration.client-tenant","Expiration for the Tenant Client certificate. 0 means no certificate or error.","Certificate Expiration",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.ca","Seconds till expiration for the CA certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.client-ca","Seconds till expiration for the client CA certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.client","Seconds till expiration for the client certificates, labeled by SQL user. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.ui-ca","Seconds till expiration for the UI CA certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.node","Seconds till expiration for the node certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.node-client","Seconds till expiration for the node's client certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.ui","Seconds till expiration for the UI certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.ca-client-tenant","Seconds till expiration for the Tenant Client CA certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
"security.certificate.ttl.client-tenant","Seconds till expiration for the Tenant Client certificate. 0 means expired, no certificate or error.","Certificate TTL",GAUGE,TIMESTAMP_SEC
252 changes: 252 additions & 0 deletions src/current/_data/v24.3/metrics/child-metrics.yml
Original file line number Diff line number Diff line change
@@ -0,0 +1,252 @@
# child-metrics.yml is a manually curated file of metrics that are included in the Child Metrics.
# The metrics are in the order of appearance in the comment:
# https://github.com/cockroachdb/cockroach/issues/124343#issuecomment-2117886012
# The tenant.consumption.* metrics are not included because they only apply to serverless.
#
# The corresponding metrics-list.csv file was generated using the v24.1.0 binary with the following command:
# cockroach gen metric-list --format=csv > metrics-list.csv
# Once generated, the metrics-list.csv was manually modified to change the case of the headers to lowercase to work with liquid comparison code.

- child_metric_id: changefeed.error_retries
feature: changefeed

- child_metric_id: changefeed.emitted_messages
feature: changefeed

- child_metric_id: changefeed.emitted_batch_sizes
feature: changefeed

- child_metric_id: changefeed.filtered_messages
feature: changefeed

- child_metric_id: changefeed.message_size_hist
feature: changefeed

- child_metric_id: changefeed.emitted_bytes
feature: changefeed

- child_metric_id: changefeed.flushed_bytes
feature: changefeed

- child_metric_id: changefeed.flushes
feature: changefeed

- child_metric_id: changefeed.size_based_flushes
feature: changefeed

- child_metric_id: changefeed.parallel_io_queue_nanos
feature: changefeed

- child_metric_id: changefeed.parallel_io_pending_rows
feature: changefeed

- child_metric_id: changefeed.parallel_io_result_queue_nanos
feature: changefeed

- child_metric_id: changefeed.parallel_io_in_flight_keys
feature: changefeed

- child_metric_id: changefeed.sink_io_inflight
feature: changefeed

- child_metric_id: changefeed.sink_batch_hist_nanos
feature: changefeed

- child_metric_id: changefeed.flush_hist_nanos
feature: changefeed

- child_metric_id: changefeed.commit_latency
feature: changefeed

- child_metric_id: changefeed.admit_latency
feature: changefeed

- child_metric_id: changefeed.backfill_count
feature: changefeed

- child_metric_id: changefeed.backfill_pending_ranges
feature: changefeed

- child_metric_id: changefeed.running
feature: changefeed

- child_metric_id: changefeed.batch_reduction_count
feature: changefeed

- child_metric_id: changefeed.internal_retry_message_count
feature: changefeed

- child_metric_id: changefeed.schema_registry.retry_count
feature: changefeed

- child_metric_id: changefeed.schema_registry.registrations
feature: changefeed

- child_metric_id: changefeed.aggregator_progress
feature: changefeed

- child_metric_id: changefeed.checkpoint_progress
feature: changefeed

- child_metric_id: changefeed.lagging_ranges
feature: changefeed

- child_metric_id: changefeed.cloudstorage_buffered_bytes
feature: changefeed

- child_metric_id: changefeed.kafka_throttling_hist_nanos
feature: changefeed

- child_metric_id: livebytes
feature: virtual

- child_metric_id: keybytes
feature: virtual

- child_metric_id: valbytes
feature: virtual

- child_metric_id: rangekeybytes
feature: virtual

- child_metric_id: rangevalbytes
feature: virtual

- child_metric_id: totalbytes
feature: virtual

- child_metric_id: intentbytes
feature: virtual

- child_metric_id: lockbytes
feature: virtual

- child_metric_id: livecount
feature: virtual

- child_metric_id: keycount
feature: virtual

- child_metric_id: valcount
feature: virtual

- child_metric_id: rangekeycount
feature: virtual

- child_metric_id: rangevalcount
feature: virtual

- child_metric_id: intentcount
feature: virtual

- child_metric_id: lockcount
feature: virtual

- child_metric_id: intentage
feature: virtual

- child_metric_id: gcbytesage
feature: virtual

- child_metric_id: sysbytes
feature: virtual

- child_metric_id: syscount
feature: virtual

- child_metric_id: abortspanbytes
feature: virtual

- child_metric_id: kv.tenant_rate_limit.num_tenants
feature: virtual

- child_metric_id: kv.tenant_rate_limit.current_blocked
feature: virtual

- child_metric_id: kv.tenant_rate_limit.read_batches_admitted
feature: virtual

- child_metric_id: kv.tenant_rate_limit.write_batches_admitted
feature: virtual

- child_metric_id: kv.tenant_rate_limit.read_requests_admitted
feature: virtual

- child_metric_id: kv.tenant_rate_limit.write_requests_admitted
feature: virtual

- child_metric_id: kv.tenant_rate_limit.read_bytes_admitted
feature: virtual

- child_metric_id: kv.tenant_rate_limit.write_bytes_admitted
feature: virtual

- child_metric_id: security.certificate.expiration.client
feature: secure
description: "Minimum expiration for client certificates, labeled by SQL user. 0 means no certificate or error."
type: GAUGE
unit: SECONDS

- child_metric_id: jobs.row_level_ttl.span_total_duration
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.select_duration
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.delete_duration
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.rows_selected
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.rows_deleted
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.num_active_spans
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.total_rows
feature: row-level-ttl

- child_metric_id: jobs.row_level_ttl.total_expired_rows
feature: row-level-ttl

- child_metric_id: rpc.connection.healthy
feature: all

- child_metric_id: rpc.connection.unhealthy
feature: all

- child_metric_id: rpc.connection.inactive
feature: all

- child_metric_id: rpc.connection.healthy_nanos
feature: all

- child_metric_id: rpc.connection.unhealthy_nanos
feature: all

- child_metric_id: rpc.connection.heartbeats
feature: all

- child_metric_id: rpc.connection.failures
feature: all

- child_metric_id: rpc.connection.avg_round_trip_latency
feature: all

- child_metric_id: logical_replication.catchup_ranges_by_label
feature: ldr

- child_metric_id: logical_replication.events_dlqed_by_label
feature: ldr

- child_metric_id: logical_replication.events_ingested_by_label
feature: ldr

- child_metric_id: logical_replication.replicated_time_by_label
feature: ldr

- child_metric_id: logical_replication.scanning_ranges_by_label
feature: ldr

Original file line number Diff line number Diff line change
Expand Up @@ -563,6 +563,15 @@ STORAGE,raft.entrycache.bytes,Aggregate size of all Raft entries in the Raft ent
STORAGE,raft.entrycache.hits,Number of successful cache lookups in the Raft entry cache,Hits,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.entrycache.read_bytes,Counter of bytes in entries returned from the Raft entry cache,Bytes,COUNTER,BYTES,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.entrycache.size,Number of Raft entries in the Raft entry cache,Entry Count,GAUGE,COUNT,AVG,NONE
STORAGE,raft.flows.entered.state_probe,The number of leader->peer flows transitioned to StateProbe,Flows,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.flows.entered.state_replicate,The number of leader->peer flows transitioned to StateReplicate,Flows,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.flows.entered.state_snapshot,The number of of leader->peer flows transitioned to StateSnapshot,Flows,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.flows.state_probe,Number of leader->peer flows in StateProbe,Flows,GAUGE,COUNT,AVG,NONE
STORAGE,raft.flows.state_replicate,Number of leader->peer flows in StateReplicate,Flows,GAUGE,COUNT,AVG,NONE
STORAGE,raft.flows.state_snapshot,Number of leader->peer flows in StateSnapshot,Flows,GAUGE,COUNT,AVG,NONE
STORAGE,raft.fortification.skipped_no_support,The number of fortification requests that were skipped (not sent) due to lack of store liveness support,Skipped Fortifications,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.fortification_resp.accepted,The number of accepted fortification responses. Calculated on the raft leader,Accepted Fortification Responses,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.fortification_resp.rejected,The number of rejected fortification responses. Calculated on the raft leader,Rejected Fortification Responses,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
STORAGE,raft.heartbeats.pending,Number of pending heartbeats and responses waiting to be coalesced,Messages,GAUGE,COUNT,AVG,NONE
STORAGE,raft.loaded_entries.bytes,Bytes allocated by raft Storage.Entries calls that are still kept in memory,Bytes,GAUGE,BYTES,AVG,NONE
STORAGE,raft.loaded_entries.reserved.bytes,Bytes allocated by raft Storage.Entries calls that are still kept in memory,Memory,GAUGE,BYTES,AVG,NONE
Expand Down Expand Up @@ -1328,6 +1337,7 @@ APPLICATION,distsender.rangefeed.catchup_ranges,"Number of ranges in catchup mod

This counts the number of ranges with an active rangefeed that are performing catchup scan.
",Ranges,GAUGE,COUNT,AVG,NONE
APPLICATION,distsender.rangefeed.catchup_ranges_waiting_client_side,Number of ranges waiting on the client-side limiter to perform catchup scans,Ranges,GAUGE,COUNT,AVG,NONE
APPLICATION,distsender.rangefeed.error_catchup_ranges,Number of ranges in catchup mode which experienced an error,Ranges,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,distsender.rangefeed.local_ranges,Number of ranges connected to local node.,Ranges,GAUGE,COUNT,AVG,NONE
APPLICATION,distsender.rangefeed.restart_ranges,Number of ranges that were restarted due to transient errors,Ranges,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
Expand Down Expand Up @@ -2654,6 +2664,8 @@ APPLICATION,txn.commits_read_only,Number of read only KV transaction commits,KV
APPLICATION,txn.condensed_intent_spans,KV transactions that have exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). See also txn.condensed_intent_spans_gauge for a gauge of such transactions currently running.,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,txn.condensed_intent_spans_gauge,KV transactions currently running that have exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). See also txn.condensed_intent_spans for a perpetual counter/rate.,KV Transactions,GAUGE,COUNT,AVG,NONE
APPLICATION,txn.condensed_intent_spans_rejected,KV transactions that have been aborted because they exceeded their intent tracking memory budget (kv.transaction.max_intents_bytes). Rejection is caused by kv.transaction.reject_over_max_intents_budget.,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,txn.count_limit_on_response,KV transactions that have exceeded the count limit on a response,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,txn.count_limit_rejected,KV transactions that have been aborted because they exceeded the max number of writes and locking reads allowed,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,txn.durations,KV transaction durations,KV Txn Duration,HISTOGRAM,NANOSECONDS,AVG,NONE
APPLICATION,txn.inflight_locks_over_tracking_budget,KV transactions whose in-flight writes and locking reads have exceeded the intent tracking memory budget (kv.transaction.max_intents_bytes).,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
APPLICATION,txn.parallelcommits,Number of KV transaction parallel commits,KV Transactions,COUNTER,COUNT,AVG,NON_NEGATIVE_DERIVATIVE
Expand Down
Loading

0 comments on commit 10bb275

Please sign in to comment.