Supported OS Linux Windows Mac OS

概要

Datadog の Cockroach Cloud インテグレーションは、Datadog プラットフォームを利用して、Prometheus エンドポイントで利用できる CockroachDB メトリックのサブセットに関するデータ収集とアラートを可能にします。

計画と使用

インフラストラクチャーリスト

Cockroach Cloud クラスターに対して Datadog のモニタリングを有効にするには

  1. クラスターの Monitoring ページで、Datadog パネルの Setup をクリックします。

  2. API keyDatadog Site のフィールドに、対応する値を入力します。

    • API key は、Datadog の組織と関連付けられています。Cockroach Cloud クラスターで使用する API キーをお持ちでない場合は、作成する必要があります。手順については、Datadog のドキュメントを参照してください。
    • Datadog Site は、Datadog Site URL に対応します。詳細は、Datadog のドキュメントを参照してください。
  3. Create をクリックします。クラスターのサイズとシステムの現在の負荷によって、インテグレーションが有効になるまでに時間がかかる場合があります。

  4. Datadog に登録されると、Datadog のインフラストラクチャーリストにクラスターが表示されます。これには最大で数分かかることがあります。

ブラウザトラブルシューティング

Datadog Dashboard List を開き、CockroachDB Dedicated Overview をクリックします。このダッシュボードには、CockroachDB Dedicated Overview のメトリクスが表示されます。

独自の Cockroach Cloud ダッシュボードを作成するには、デフォルトの CockroachDB Dedicated Overview ダッシュボードを複製してウィジェットを編集するか、または新しいダッシュボードを作成します。

利用可能なメトリクスは、CockroachDB Prometheus エンドポイントから直接取得したもので、独自のグラフの構成要素として使用することを想定しています。

収集されるメトリクスをプレビューするには、以下の方法があります。

検証

有効化されると、Monitoring ページの Datadog パネルにある Integration status は、Active と表示されるようになります。

インテグレーション中に問題が発生した場合、代わりに以下のステータスのいずれかが表示されることがあります。

  • Active は、インテグレーションが正常にデプロイされたことを示します。
  • Inactive は、インテグレーションが正常にデプロイされていないことを示します。セットアップが行われていないか、エラーが発生したことを示します。
  • Unhealthy は、インテグレーション API キーが無効で、更新する必要があることを示します。
  • Unknown は、不明なエラーが発生したことを示します。このステータスが表示された場合は、サポートチームにお問い合わせください

CockroachDB からのメトリクスエクスポートは、以下のような場合に中断されることがあります。

  • API キーが古くなっている。この場合、インテグレーションのステータスは Unhealthy になります。この問題を解決するには、新しい API キーを使ってインテグレーションを更新してください。
  • CockroachDB が一時的に使用できない。この場合、インテグレーションのステータスは Active のままです。この問題を解決するには、Datadog パネルからインテグレーションを非アクティブ化して再アクティブ化してみてください。それでも問題が解決しない場合は、サポートチームにご連絡ください

メトリクスエクスポートの健全性を監視するには、Datadog でカスタムモニターを作成することができます。

インテグレーションの更新

インテグレーションに関連するメタデータを更新するには (例えば、API キーをローテーションする)

  1. Datadog パネルで、省略記号をクリックし、Update を選択します。

  2. API keyDatadog Site フィールドを更新し、Create をクリックします。インテグレーションが再デプロイされます。

インテグレーションの非アクティブ化

インテグレーションを非アクティブにするには

  1. Datadog パネルで、省略記号をクリックし、Deactivate integration を選択します。

  2. 無効になると、パネル内の Integration status が、Inactive と表示されます。

インテグレーションを非アクティブにした後も、メトリクスデータは Datadog にデフォルトの保持期間の間残ります。

リアルユーザーモニタリング

データセキュリティ

crdb_dedicated.addsstable.applications
(count)
Number of SSTable ingestions applied i.e. applied by Replicas. Shown as operation
Shown as operation
crdb_dedicated.addsstable.copies
(count)
number of SSTable ingestions that required copying files during application. Shown as operation
Shown as operation
crdb_dedicated.addsstable.proposals
(count)
Number of SSTable ingestions proposed i.e. sent to Raft by lease holders. Shown as operation
Shown as operation
crdb_dedicated.admission.wait.sum.kv
(count)
Total wait time in micros for requests within the KV layer
Shown as microsecond
crdb_dedicated.admission.wait.sum.kv.stores
(count)
Total wait time in micros for write requests within the KV layer
Shown as microsecond
crdb_dedicated.admission.wait.sum.sql.kv.response
(count)
Total wait time in micros for responses between the KV and SQL layer
Shown as microsecond
crdb_dedicated.admission.wait.sum.sql.sql.response
(count)
Total wait time in micros for responses within the SQL layer when receiving DistSQL responses
Shown as microsecond
crdb_dedicated.capacity
(gauge)
Total storage capacity. Shown as byte
Shown as byte
crdb_dedicated.capacity.available
(gauge)
Available storage capacity. Shown as byte
Shown as byte
crdb_dedicated.capacity.reserved
(gauge)
Capacity reserved for snapshots. Shown as byte
Shown as byte
crdb_dedicated.capacity.used
(gauge)
Used storage capacity. Shown as byte
Shown as byte
crdb_dedicated.changefeed.backfill.count
(gauge)
Number of changefeeds currently executing backfill. Shown as count.
Shown as unit
crdb_dedicated.changefeed.backfill.pending.ranges
(gauge)
Number of ranges in an ongoing backfill that are yet to be fully emitted. Shown as count
Shown as unit
crdb_dedicated.changefeed.commit.latency
(gauge)
Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink. If the sink batches events, then the difference between the oldest event in the batch and acknowledgement is recorded. Excludes latency during backfill. Shown as nanoseconds.
Shown as unit
crdb_dedicated.changefeed.emitted.messages
(count)
Messages emitted by all feeds. Shown as count.
Shown as unit
crdb_dedicated.changefeed.error.retries
(count)
Total retryable errors encountered by all changefeeds. Shown as count.
Shown as unit
crdb_dedicated.changefeed.failures
(count)
Total number of changefeed jobs which have failed. Shown as count.
Shown as unit
crdb_dedicated.changefeed.max.behind.nanos
(gauge)
Largest commit-to-emit duration of any running feed. Shown as nanoseconds.
Shown as nanosecond
crdb_dedicated.changefeed.message.size.hist
(gauge)
Histogram of message sizes for changefeeds. Shown as bytes.
Shown as byte
crdb_dedicated.changefeed.running
(gauge)
Number of currently running changefeeds, including sinkless. Shown as count.
Shown as unit
crdb_dedicated.clock.offset.meannanos
(gauge)
Mean clock offset with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.clock.offset.stddevnanos
(gauge)
Stdddev clock offset with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.distsender.batches
(count)
Number of batches processed
crdb_dedicated.distsender.batches.partial
(count)
Number of partial batches processed
crdb_dedicated.distsender.errors.notleaseholder
(count)
Number of NotLeaseHolderErrors encountered. Shown as error
Shown as error
crdb_dedicated.distsender.rpc.sent
(count)
Number of RPCs sent
Shown as request
crdb_dedicated.distsender.rpc.sent.local
(count)
Number of local RPCs sent
Shown as request
crdb_dedicated.distsender.rpc.sent.nextreplicaerror
(count)
Number of RPCs sent due to per-replica errors. Shown as error
Shown as request
crdb_dedicated.exec.error
(count)
Number of batch KV requests that failed to execute on this node. Shown as request
Shown as request
crdb_dedicated.exec.latency
(count)
Latency in nanoseconds of batch KV requests executed on this node. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.exec.success
(count)
Number of batch KV requests executed successfully on this node. Shown as request
Shown as request
crdb_dedicated.gcbytesage
(gauge)
Cumulative age of non-live data in seconds. Shown as second
Shown as second
crdb_dedicated.gossip.bytes.received
(count)
Number of received gossip bytes. Shown as byte
Shown as byte
crdb_dedicated.gossip.bytes.sent
(count)
Number of sent gossip bytes. Shown as byte
Shown as byte
crdb_dedicated.gossip.connections.incoming
(gauge)
Number of active incoming gossip connections. Shown as connection
Shown as connection
crdb_dedicated.gossip.connections.outgoing
(gauge)
Number of active outgoing gossip connections. Shown as connection
Shown as connection
crdb_dedicated.gossip.connections.refused
(count)
Number of refused incoming gossip connections. Shown as connection
Shown as connection
crdb_dedicated.gossip.infos.received
(count)
Number of received gossip Info objects
Shown as message
crdb_dedicated.gossip.infos.sent
(count)
Number of sent gossip Info objects
Shown as message
crdb_dedicated.intentage
(gauge)
Cumulative age of intents in seconds. Shown as second
Shown as second
crdb_dedicated.intentbytes
(gauge)
Number of bytes in intent KV pairs. Shown as byte
Shown as byte
crdb_dedicated.intentcount
(gauge)
Count of intent keys. Shown as key
Shown as key
crdb_dedicated.jobs.changefeed.resume.retry.error
(count)
Number of changefeed jobs which failed with a retriable error. Shown as count.
Shown as unit
crdb_dedicated.keybytes
(gauge)
Number of bytes taken up by keys. Shown as byte
Shown as byte
crdb_dedicated.keycount
(gauge)
Count of all keys. Shown as key
Shown as key
crdb_dedicated.leases.epoch
(gauge)
Number of replica leaseholders using epoch-based leases
Shown as unit
crdb_dedicated.leases.error
(count)
Number of failed lease requests. Shown as request
Shown as request
crdb_dedicated.leases.expiration
(gauge)
Number of replica leaseholders using expiration-based leases
Shown as unit
crdb_dedicated.leases.success
(count)
Number of successful lease requests. Shown as request
Shown as request
crdb_dedicated.leases.transfers.error
(count)
Number of failed lease transfers
Shown as error
crdb_dedicated.leases.transfers.success
(count)
Number of successful lease transfers
Shown as success
crdb_dedicated.livebytes
(gauge)
Number of bytes of live data keys plus values. Shown as byte
Shown as byte
crdb_dedicated.livecount
(gauge)
Count of live keys. Shown as key
Shown as key
crdb_dedicated.liveness.epochincrements
(count)
Number of times this node has incremented its liveness epoch
Shown as unit
crdb_dedicated.liveness.heartbeatfailures
(count)
Number of failed node liveness heartbeats from this node
Shown as unit
crdb_dedicated.liveness.heartbeatlatency
(count)
Node liveness heartbeat latency in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.liveness.heartbeatsuccesses
(count)
Number of successful node liveness heartbeats from this node
Shown as unit
crdb_dedicated.liveness.livenodes
(gauge)
Number of live nodes in the cluster will be 0 if this node is not itself live
Shown as unit
crdb_dedicated.queue.consistency.pending
(gauge)
Number of pending replicas in the consistency checker queue
Shown as unit
crdb_dedicated.queue.consistency.process.failure
(count)
Number of replicas which failed processing in the consistency checker queue
Shown as unit
crdb_dedicated.queue.consistency.process.success
(count)
Number of replicas successfully processed by the consistency checker queue
Shown as success
crdb_dedicated.queue.consistency.processingnanos
(count)
Nanoseconds spent processing replicas in the consistency checker queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.gc.info.abortspanconsidered
(count)
Number of AbortSpan entries old enough to be considered for removal
Shown as transaction
crdb_dedicated.queue.gc.info.abortspangcnum
(count)
Number of AbortSpan entries fit for removal
Shown as transaction
crdb_dedicated.queue.gc.info.abortspanscanned
(count)
Number of transactions present in the AbortSpan scanned from the engine. Shown as transaction
Shown as transaction
crdb_dedicated.queue.gc.info.intentsconsidered
(count)
Number of 'old' intents
Shown as transaction
crdb_dedicated.queue.gc.info.intenttxns
(count)
Number of associated distinct transactions. Shown as transaction
Shown as key
crdb_dedicated.queue.gc.info.numkeysaffected
(count)
Number of keys with GC'able data. Shown as key
Shown as key
crdb_dedicated.queue.gc.info.pushtxn
(count)
Number of attempted pushes
Shown as attempt
crdb_dedicated.queue.gc.info.resolvesuccess
(count)
Number of successful intent resolutions
Shown as success
crdb_dedicated.queue.gc.info.resolvetotal
(count)
Number of attempted intent resolutions
Shown as attempt
crdb_dedicated.queue.gc.info.transactionspangcaborted
(count)
Number of GC'able entries corresponding to aborted txns
Shown as unit
crdb_dedicated.queue.gc.info.transactionspangccommitted
(count)
Number of GC'able entries corresponding to committed txns
Shown as commit
crdb_dedicated.queue.gc.info.transactionspangcpending
(count)
Number of GC'able entries corresponding to pending txns
Shown as unit
crdb_dedicated.queue.gc.info.transactionspanscanned
(count)
Number of entries in transaction spans scanned from the engine
Shown as unit
crdb_dedicated.queue.gc.pending
(gauge)
Number of pending replicas in the GC queue
Shown as unit
crdb_dedicated.queue.gc.process.failure
(count)
Number of replicas which failed processing in the GC queue
Shown as unit
crdb_dedicated.queue.gc.process.success
(count)
Number of replicas successfully processed by the GC queue
Shown as success
crdb_dedicated.queue.gc.processingnanos
(count)
Nanoseconds spent processing replicas in the GC queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.raftlog.pending
(gauge)
Number of pending replicas in the Raft log queue
Shown as unit
crdb_dedicated.queue.raftlog.process.failure
(count)
Number of replicas which failed processing in the Raft log queue
Shown as unit
crdb_dedicated.queue.raftlog.process.success
(count)
Number of replicas successfully processed by the Raft log queue
Shown as unit
crdb_dedicated.queue.raftlog.processingnanos
(count)
Nanoseconds spent processing replicas in the Raft log queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.raftsnapshot.pending
(gauge)
Number of pending replicas in the Raft repair queue
Shown as unit
crdb_dedicated.queue.raftsnapshot.process.failure
(count)
Number of replicas which failed processing in the Raft repair queue
Shown as unit
crdb_dedicated.queue.raftsnapshot.process.success
(count)
Number of replicas successfully processed by the Raft repair queue
Shown as unit
crdb_dedicated.queue.raftsnapshot.processingnanos
(count)
Nanoseconds spent processing replicas in the Raft repair queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.replicagc.pending
(gauge)
Number of pending replicas in the replica GC queue
Shown as unit
crdb_dedicated.queue.replicagc.process.failure
(count)
Number of replicas which failed processing in the replica GC queue
Shown as unit
crdb_dedicated.queue.replicagc.process.success
(count)
Number of replicas successfully processed by the replica GC queue
Shown as unit
crdb_dedicated.queue.replicagc.processingnanos
(count)
Nanoseconds spent processing replicas in the replica GC queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.replicagc.removereplica
(count)
Number of replica removals attempted by the replica gc queue
Shown as unit
crdb_dedicated.queue.replicate.addreplica
(count)
Number of replica additions attempted by the replicate queue
Shown as unit
crdb_dedicated.queue.replicate.pending
(gauge)
Number of pending replicas in the replicate queue
Shown as unit
crdb_dedicated.queue.replicate.process.failure
(count)
Number of replicas which failed processing in the replicate queue
Shown as unit
crdb_dedicated.queue.replicate.process.success
(count)
Number of replicas successfully processed by the replicate queue
Shown as unit
crdb_dedicated.queue.replicate.processingnanos
(count)
Nanoseconds spent processing replicas in the replicate queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.replicate.purgatory
(gauge)
Number of replicas in the replicate queue's purgatory, awaiting allocation options
Shown as unit
crdb_dedicated.queue.replicate.rebalancereplica
(count)
Number of replica rebalancer-initiated additions attempted by the replicate queue
Shown as unit
crdb_dedicated.queue.replicate.removedeadreplica
(count)
Number of dead replica removals attempted by the replicate queue typically in response to a node outage
Shown as unit
crdb_dedicated.queue.replicate.removereplica
(count)
Number of replica removals attempted by the replicate queue typically in response to a rebalancer-initiated addition
Shown as unit
crdb_dedicated.queue.replicate.transferlease
(count)
Number of range lease transfers attempted by the replicate queue
Shown as unit
crdb_dedicated.queue.split.pending
(gauge)
Number of pending replicas in the split queue
Shown as unit
crdb_dedicated.queue.split.process.failure
(count)
Number of replicas which failed processing in the split queue
Shown as unit
crdb_dedicated.queue.split.process.success
(count)
Number of replicas successfully processed by the split queue
Shown as unit
crdb_dedicated.queue.split.processingnanos
(count)
Nanoseconds spent processing replicas in the split queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.queue.tsmaintenance.pending
(gauge)
Number of pending replicas in the timeseries maintenance queue
Shown as unit
crdb_dedicated.queue.tsmaintenance.process.failure
(count)
Number of replicas which failed processing in the timeseries maintenance queue
Shown as unit
crdb_dedicated.queue.tsmaintenance.process.success
(count)
Number of replicas successfully processed by the timeseries maintenance queue
Shown as unit
crdb_dedicated.queue.tsmaintenance.processingnanos
(count)
Nanoseconds spent processing replicas in the timeseries maintenance queue. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.raft.commandsapplied
(count)
Count of Raft commands applied. Shown as command
Shown as command
crdb_dedicated.raft.enqueued.pending
(gauge)
Number of pending outgoing messages in the Raft Transport queue
Shown as unit
crdb_dedicated.raft.heartbeats.pending
(gauge)
Number of pending heartbeats and responses waiting to be coalesced
Shown as unit
crdb_dedicated.raft.process.commandcommit.latency
(count)
Latency histogram in nanoseconds for committing Raft commands. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.raft.process.logcommit.latency
(count)
Latency histogram in nanoseconds for committing Raft log entries. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.raft.process.tickingnanos
(count)
Nanoseconds spent in store.processRaft processing replica.Tick. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.raft.process.workingnanos
(count)
Nanoseconds spent in store.processRaft working. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.raft.rcvd.app
(count)
Number of MsgApp messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.appresp
(count)
Number of MsgAppResp messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.dropped
(count)
Number of dropped incoming Raft messages
Shown as message
crdb_dedicated.raft.rcvd.heartbeat
(count)
Number of coalesced, if enabled MsgHeartbeat messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.heartbeatresp
(count)
Number of coalesced, if enabled MsgHeartbeatResp messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.prevote
(count)
Number of MsgPreVote messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.prevoteresp
(count)
Number of MsgPreVoteResp messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.prop
(count)
Number of MsgProp messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.snap
(count)
Number of MsgSnap messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.timeoutnow
(count)
Number of MsgTimeoutNow messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.transferleader
(count)
Number of MsgTransferLeader messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.vote
(count)
Number of MsgVote messages received by this store
Shown as message
crdb_dedicated.raft.rcvd.voteresp
(count)
Number of MsgVoteResp messages received by this store
Shown as message
crdb_dedicated.raft.ticks
(count)
Number of Raft ticks queued
Shown as unit
crdb_dedicated.raftlog.behind
(gauge)
Number of Raft log entries followers on other stores are behind. Shown as entry
Shown as unit
crdb_dedicated.raftlog.truncated
(count)
Number of Raft log entries truncated. Shown as entry
Shown as unit
crdb_dedicated.range.adds
(count)
Number of range additions
Shown as unit
crdb_dedicated.range.raftleadertransfers
(count)
Number of raft leader transfers
Shown as unit
crdb_dedicated.range.removes
(count)
Number of range removals
Shown as unit
crdb_dedicated.range.snapshots.generated
(count)
Number of generated snapshots
Shown as unit
crdb_dedicated.range.splits
(count)
Number of range splits
Shown as unit
crdb_dedicated.ranges
(gauge)
Number of ranges
Shown as unit
crdb_dedicated.ranges.overreplicated
(gauge)
Number of ranges with more live replicas than the replication target
Shown as unit
crdb_dedicated.ranges.unavailable
(gauge)
Number of ranges with fewer live replicas than needed for quorum
Shown as unit
crdb_dedicated.ranges.underreplicated
(gauge)
Number of ranges with fewer live replicas than the replication target
Shown as unit
crdb_dedicated.rebalancing.writespersecond
(gauge)
Number of keys written i.e. applied by raft per second to the store, averaged over a large time period as used in rebalancing decisions. Shown as key
Shown as unit
crdb_dedicated.replicas
(gauge)
Number of replicas
Shown as unit
crdb_dedicated.replicas.leaders
(gauge)
Number of raft leaders
Shown as unit
crdb_dedicated.replicas.leaders.not_leaseholders
(gauge)
Number of replicas that are Raft leaders whose range lease is held by another store
Shown as unit
crdb_dedicated.replicas.leaseholders
(gauge)
Number of lease holders
Shown as unit
crdb_dedicated.replicas.quiescent
(gauge)
Number of quiesced replicas
Shown as unit
crdb_dedicated.replicas.reserved
(gauge)
Number of replicas reserved for snapshots
Shown as unit
crdb_dedicated.requests.backpressure.split
(gauge)
Number of backpressured writes waiting on a Range split
Shown as unit
crdb_dedicated.requests.slow.distsender
(gauge)
Number of requests that have been stuck for a long time in the dist sender. Shown as request
Shown as request
crdb_dedicated.requests.slow.lease
(gauge)
Number of requests that have been stuck for a long time acquiring a lease. Shown as request
Shown as request
crdb_dedicated.requests.slow.raft
(gauge)
Number of requests that have been stuck for a long time in raft. Shown as request
Shown as request
crdb_dedicated.rocksdb.block.cache.hits
(gauge)
Count of block cache hits
Shown as hit
crdb_dedicated.rocksdb.block.cache.misses
(gauge)
Count of block cache misses
Shown as miss
crdb_dedicated.rocksdb.block.cache.pinned.usage
(gauge)
Bytes pinned by the block cache. Shown as byte
Shown as byte
crdb_dedicated.rocksdb.block.cache.usage
(gauge)
Bytes used by the block cache. Shown as byte
Shown as byte
crdb_dedicated.rocksdb.bloom_filter.prefix.checked
(gauge)
Number of times the bloom filter was checked
Shown as unit
crdb_dedicated.rocksdb.bloom_filter.prefix.useful
(gauge)
Number of times the bloom filter helped avoid iterator creation
Shown as unit
crdb_dedicated.rocksdb.compactions
(gauge)
Number of table compactions
Shown as unit
crdb_dedicated.rocksdb.flushes
(gauge)
Number of table flushes
Shown as flush
crdb_dedicated.rocksdb.memtable.total.size
(gauge)
Current size of memtable in bytes. Shown as byte
Shown as byte
crdb_dedicated.rocksdb.num_sstables
(gauge)
Number of rocksdb SSTables. Shown as table
Shown as table
crdb_dedicated.rocksdb.read.amplification
(gauge)
Number of disk reads per query. Shown as read
Shown as read
crdb_dedicated.rocksdb.table.readers.mem.estimate
(gauge)
Memory used by index and filter blocks
Shown as unit
crdb_dedicated.round_trip.latency
(count)
Distribution of round-trip latencies with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sql.bytesin
(count)
Number of sql bytes received. Shown as byte
Shown as byte
crdb_dedicated.sql.bytesout
(count)
Number of sql bytes sent. Shown as byte
Shown as byte
crdb_dedicated.sql.conn.latency
(count)
Latency to establish and authenticate a SQL connection. Shown as nanoseconds.
Shown as nanosecond
crdb_dedicated.sql.conns
(gauge)
Number of active sql connections. Shown as connection
Shown as connection
crdb_dedicated.sql.ddl.count
(count)
Number of SQL DDL statements
Shown as query
crdb_dedicated.sql.delete.count
(count)
Number of SQL DELETE statements
Shown as query
crdb_dedicated.sql.distsql.contended.queries.count
(count)
Number of SQL queries that experienced contention. Shown as count.
Shown as query
crdb_dedicated.sql.distsql.exec.latency
(count)
Latency in nanoseconds of DistSQL statement execution. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sql.distsql.flows.active
(gauge)
Number of distributed SQL flows currently active
Shown as query
crdb_dedicated.sql.distsql.flows.total
(count)
Number of distributed SQL flows executed
Shown as query
crdb_dedicated.sql.distsql.queries.active
(gauge)
Number of distributed SQL queries currently active
Shown as query
crdb_dedicated.sql.distsql.queries.total
(count)
Number of distributed SQL queries executed
Shown as query
crdb_dedicated.sql.distsql.select.count
(count)
Number of DistSQL SELECT statements
Shown as unit
crdb_dedicated.sql.distsql.service.latency
(count)
Latency in nanoseconds of DistSQL request execution. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sql.exec.latency
(count)
Latency in nanoseconds of SQL statement execution. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sql.failure.count
(count)
Number of statements resulting in a planning or runtime error. Shown as count.
Shown as unit
crdb_dedicated.sql.full.scan.count
(count)
Number of full table or index scans. Shown as count.
Shown as unit
crdb_dedicated.sql.insert.count
(count)
Number of SQL INSERT statements
Shown as unit
crdb_dedicated.sql.mem.distsql.current
(gauge)
Current sql statement memory usage for distsql
Shown as unit
crdb_dedicated.sql.mem.distsql.max
(count)
Memory usage per sql statement for distsql
Shown as unit
crdb_dedicated.sql.mem.internal.session.current
(gauge)
Current sql session memory usage for internal
Shown as unit
crdb_dedicated.sql.mem.internal.session.max
(count)
Memory usage per sql session for internal
Shown as unit
crdb_dedicated.sql.mem.internal.txn.current
(gauge)
Current sql transaction memory usage for internal
Shown as unit
crdb_dedicated.sql.mem.internal.txn.max
(count)
Memory usage per sql transaction for internal
Shown as unit
crdb_dedicated.sql.misc.count
(count)
Number of other SQL statements
Shown as query
crdb_dedicated.sql.new_conns.count
(count)
Number of SQL connections created
Shown as connection
crdb_dedicated.sql.query.count
(count)
Number of SQL queries
Shown as query
crdb_dedicated.sql.select.count
(count)
Number of SQL SELECT statements
Shown as query
crdb_dedicated.sql.service.latency
(count)
Latency in nanoseconds of SQL request execution. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sql.statements.active
(gauge)
Number of currently active user SQL statements. Shown as count.
Shown as unit
crdb_dedicated.sql.txn.abort.count
(count)
Number of SQL transaction ABORT statements
Shown as unit
crdb_dedicated.sql.txn.begin.count
(count)
Number of SQL transaction BEGIN statements
Shown as unit
crdb_dedicated.sql.txn.commit.count
(count)
Number of SQL transaction COMMIT statements
Shown as unit
crdb_dedicated.sql.txn.latency
(count)
Latency of SQL transactions. Shown as nanoseconds.
Shown as unit
crdb_dedicated.sql.txn.rollback.count
(count)
Number of SQL transaction ROLLBACK statements
Shown as unit
crdb_dedicated.sql.txns.open
(gauge)
Number of currently open SQL transactions. Shown as count.
Shown as unit
crdb_dedicated.sql.update.count
(count)
Number of SQL UPDATE statements
Shown as unit
crdb_dedicated.sys.cgo.allocbytes
(gauge)
Current bytes of memory allocated by cgo. Shown as byte
Shown as byte
crdb_dedicated.sys.cgo.totalbytes
(gauge)
Total bytes of memory allocated by cgo, but not released. Shown as byte
Shown as byte
crdb_dedicated.sys.cgocalls
(gauge)
Total number of cgo calls
Shown as unit
crdb_dedicated.sys.cpu.combined.percent.normalized
(gauge)
Current user+system cpu percentage, normalized 0-1 by number of cores.
Shown as fraction
crdb_dedicated.sys.cpu.sys.ns
(gauge)
Total system cpu time in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sys.cpu.sys.percent
(gauge)
Current system cpu percentage
Shown as core
crdb_dedicated.sys.cpu.user.ns
(gauge)
Total user cpu time in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sys.cpu.user.percent
(gauge)
Current user cpu percentage. Shown as percent
Shown as core
crdb_dedicated.sys.fd.open
(gauge)
Process open file descriptors
Shown as unit
crdb_dedicated.sys.fd.softlimit
(gauge)
Process open FD soft limit
Shown as unit
crdb_dedicated.sys.gc.count
(gauge)
Total number of GC runs
Shown as garbage collection
crdb_dedicated.sys.gc.pause.ns
(gauge)
Total GC pause in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_dedicated.sys.gc.pause.percent
(gauge)
Current GC pause percentage. Shown as fraction
Shown as fraction
crdb_dedicated.sys.go.allocbytes
(gauge)
Current bytes of memory allocated by go. Shown as byte
Shown as byte
crdb_dedicated.sys.go.totalbytes
(gauge)
Total bytes of memory allocated by go, but not released. Shown as byte
Shown as byte
crdb_dedicated.sys.goroutines
(gauge)
Current number of goroutines
Shown as unit
crdb_dedicated.sys.host.net.recv.bytes
(gauge)
Bytes received on all network interfaces since this process started.
Shown as byte
crdb_dedicated.sys.host.net.send.bytes
(gauge)
Bytes sent on all network interfaces since this process started.
Shown as byte
crdb_dedicated.sys.rss
(gauge)
Current process RSS
Shown as unit
crdb_dedicated.sys.uptime
(gauge)
Process uptime in seconds. Shown as second
Shown as second
crdb_dedicated.sysbytes
(gauge)
Number of bytes in system KV pairs. Shown as byte
Shown as byte
crdb_dedicated.syscount
(gauge)
Count of system KV pairs
Shown as unit
crdb_dedicated.timeseries.write.bytes
(count)
Total size in bytes of metric samples written to disk. Shown as byte
Shown as byte
crdb_dedicated.timeseries.write.errors
(count)
Total errors encountered while attempting to write metrics to disk. Shown as error
Shown as error
crdb_dedicated.timeseries.write.samples
(count)
Total number of metric samples written to disk
Shown as unit
crdb_dedicated.totalbytes
(gauge)
Total number of bytes taken up by keys and values including non-live data. Shown as byte
Shown as byte
crdb_dedicated.txn.aborts
(count)
Number of aborted KV transactions
Shown as unit
crdb_dedicated.txn.commits
(count)
Number of committed KV transactions including 1PC
Shown as commit
crdb_dedicated.txn.commits1PC
(count)
Number of committed one-phase KV transactions
Shown as commit
crdb_dedicated.txn.durations
(count)
KV transaction durations in nanoseconds
Shown as nanosecond
crdb_dedicated.txn.restarts
(count)
Number of restarted KV transactions
Shown as unit
crdb_dedicated.txn.restarts.serializable
(count)
Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE
Shown as unit
crdb_dedicated.txn.restarts.writetooold
(count)
Number of restarts due to a concurrent writer committing first
Shown as unit
crdb_dedicated.valbytes
(gauge)
Number of bytes taken up by values. Shown as byte
Shown as byte
crdb_dedicated.valcount
(gauge)
Count of all values
Shown as unit
crdb_cloud.changefeed.backfill.count
(gauge)
Number of changefeeds currently executing backfill. Shown as count.
Shown as unit
crdb_cloud.changefeed.backfill.pending.ranges
(gauge)
Number of ranges in an ongoing backfill that are yet to be fully emitted. Shown as count
Shown as unit
crdb_cloud.changefeed.commit.latency
(gauge)
Event commit latency: a difference between event MVCC timestamp and the time it was acknowledged by the downstream sink. If the sink batches events, then the difference between the oldest event in the batch and acknowledgement is recorded. Excludes latency during backfill. Shown as nanoseconds.
Shown as unit
crdb_cloud.changefeed.emitted.messages
(count)
Messages emitted by all feeds. Shown as count.
Shown as unit
crdb_cloud.changefeed.error.retries
(count)
Total retryable errors encountered by all changefeeds. Shown as count.
Shown as unit
crdb_cloud.changefeed.failures
(count)
Total number of changefeed jobs which have failed. Shown as count.
Shown as unit
crdb_cloud.changefeed.max.behind.nanos
(gauge)
Largest commit-to-emit duration of any running feed. Shown as nanoseconds.
Shown as nanosecond
crdb_cloud.changefeed.message.size.hist
(gauge)
Histogram of message sizes for changefeeds. Shown as bytes.
Shown as byte
crdb_cloud.changefeed.running
(gauge)
Number of currently running changefeeds, including sinkless. Shown as count.
Shown as unit
crdb_cloud.clock.offset.meannanos
(gauge)
Mean clock offset with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_cloud.clock.offset.stddevnanos
(gauge)
Stdddev clock offset with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_cloud.distsender.batches
(count)
Number of batches processed
crdb_cloud.distsender.batches.partial
(count)
Number of partial batches processed
crdb_cloud.distsender.errors.notleaseholder
(count)
Number of NotLeaseHolderErrors encountered. Shown as error
Shown as error
crdb_cloud.distsender.rpc.sent
(count)
Number of RPCs sent
Shown as request
crdb_cloud.distsender.rpc.sent.local
(count)
Number of local RPCs sent
Shown as request
crdb_cloud.distsender.rpc.sent.nextreplicaerror
(count)
Number of RPCs sent due to per-replica errors. Shown as error
Shown as request
crdb_cloud.jobs.changefeed.resume.retry.error
(count)
Number of changefeed jobs which failed with a retriable error. Shown as count.
Shown as unit
crdb_cloud.requests.slow.distsender
(gauge)
Number of requests that have been stuck for a long time in the dist sender. Shown as request
Shown as request
crdb_cloud.round_trip.latency
(count)
Distribution of round-trip latencies with other nodes in nanoseconds. Shown as nanosecond
Shown as nanosecond
crdb_cloud.sql.bytesin
(count)
Number of sql bytes received. Shown as byte
Shown as byte
crdb_cloud.sql.bytesout
(count)
Number of sql bytes sent. Shown as byte
Shown as byte
crdb_cloud.sql.conn.latency
(count)
Latency to establish and authenticate a SQL connection. Shown as nanoseconds.
Shown as nanosecond
crdb_cloud.sql.conns
(gauge)
Number of active sql connections. Shown as connection
Shown as connection
crdb_cloud.sql.ddl.count
(count)
Number of SQL DDL statements
Shown as query
crdb_cloud.sql.delete.count
(count)
Number of SQL DELETE statements
Shown as query
crdb_cloud.sql.distsql.contended.queries.count
(count)
Number of SQL queries that experienced contention. Shown as count.
Shown as query
crdb_cloud.sql.distsql.exec.latency
(count)
Latency in nanoseconds of DistSQL statement execution. Shown as nanosecond
Shown as nanosecond
crdb_cloud.sql.distsql.flows.active
(gauge)
Number of distributed SQL flows currently active
Shown as query
crdb_cloud.sql.distsql.flows.total
(count)
Number of distributed SQL flows executed
Shown as query
crdb_cloud.sql.distsql.queries.active
(gauge)
Number of distributed SQL queries currently active
Shown as query
crdb_cloud.sql.distsql.queries.total
(count)
Number of distributed SQL queries executed
Shown as query
crdb_cloud.sql.distsql.select.count
(count)
Number of DistSQL SELECT statements
Shown as unit
crdb_cloud.sql.distsql.service.latency
(count)
Latency in nanoseconds of DistSQL request execution. Shown as nanosecond
Shown as nanosecond
crdb_cloud.sql.exec.latency
(count)
Latency in nanoseconds of SQL statement execution. Shown as nanosecond
Shown as nanosecond
crdb_cloud.sql.failure.count
(count)
Number of statements resulting in a planning or runtime error. Shown as count.
Shown as unit
crdb_cloud.sql.full.scan.count
(count)
Number of full table or index scans. Shown as count.
Shown as unit
crdb_cloud.sql.insert.count
(count)
Number of SQL INSERT statements
Shown as unit
crdb_cloud.sql.mem.distsql.current
(gauge)
Current sql statement memory usage for distsql
Shown as unit
crdb_cloud.sql.mem.distsql.max
(count)
Memory usage per sql statement for distsql
Shown as unit
crdb_cloud.sql.mem.internal.session.current
(gauge)
Current sql session memory usage for internal
Shown as unit
crdb_cloud.sql.mem.internal.session.max
(count)
Memory usage per sql session for internal
Shown as unit
crdb_cloud.sql.mem.internal.txn.current
(gauge)
Current sql transaction memory usage for internal
Shown as unit
crdb_cloud.sql.mem.internal.txn.max
(count)
Memory usage per sql transaction for internal
Shown as unit
crdb_cloud.sql.misc.count
(count)
Number of other SQL statements
Shown as query
crdb_cloud.sql.new_conns.count
(count)
Number of SQL connections created
Shown as connection
crdb_cloud.sql.query.count
(count)
Number of SQL queries
Shown as query
crdb_cloud.sql.select.count
(count)
Number of SQL SELECT statements
Shown as query
crdb_cloud.sql.service.latency
(count)
Latency in nanoseconds of SQL request execution. Shown as nanosecond
Shown as nanosecond
crdb_cloud.sql.statements.active
(gauge)
Number of currently active user SQL statements. Shown as count.
Shown as unit
crdb_cloud.sql.txn.abort.count
(count)
Number of SQL transaction ABORT statements
Shown as unit
crdb_cloud.sql.txn.begin.count
(count)
Number of SQL transaction BEGIN statements
Shown as unit
crdb_cloud.sql.txn.commit.count
(count)
Number of SQL transaction COMMIT statements
Shown as unit
crdb_cloud.sql.txn.latency
(count)
Latency of SQL transactions. Shown as nanoseconds.
Shown as unit
crdb_cloud.sql.txn.rollback.count
(count)
Number of SQL transaction ROLLBACK statements
Shown as unit
crdb_cloud.sql.txns.open
(gauge)
Number of currently open SQL transactions. Shown as count.
Shown as unit
crdb_cloud.sql.update.count
(count)
Number of SQL UPDATE statements
Shown as unit
crdb_cloud.sys.uptime
(gauge)
Process uptime in seconds. Shown as second
Shown as second
crdb_cloud.txn.aborts
(count)
Number of aborted KV transactions
Shown as unit
crdb_cloud.txn.commits
(count)
Number of committed KV transactions including 1PC
Shown as commit
crdb_cloud.txn.commits1PC
(count)
Number of committed one-phase KV transactions
Shown as commit
crdb_cloud.txn.durations
(count)
KV transaction durations in nanoseconds
Shown as nanosecond
crdb_cloud.txn.restarts
(count)
Number of restarted KV transactions
Shown as unit
crdb_cloud.txn.restarts.serializable
(count)
Number of restarts due to a forwarded commit timestamp and isolation=SERIALIZABLE
Shown as unit
crdb_cloud.txn.restarts.writetooold
(count)
Number of restarts due to a concurrent writer committing first
Shown as unit
crdb_cloud.tenant.sql_usage.request_units
(count)
Total RU consumption
Shown as unit
crdb_cloud.tenant.sql_usage.kv_request_units
(count)
RU consumption attributable to KV
Shown as unit
crdb_cloud.tenant.sql_usage.read_batches
(count)
Total number of KV read batches
Shown as unit
crdb_cloud.tenant.sql_usage.read_requests
(count)
Total number of KV read requests
Shown as unit
crdb_cloud.tenant.sql_usage.read_bytes
(count)
Total number of bytes read from KV
Shown as byte
crdb_cloud.tenant.sql_usage.write_batches
(count)
Total number of KV write batches
Shown as unit
crdb_cloud.tenant.sql_usage.write_requests
(count)
Total number of KV write requests
Shown as unit
crdb_cloud.tenant.sql_usage.write_bytes
(count)
Total number of bytes written to KV
Shown as byte
crdb_cloud.tenant.sql_usage.sql_pods_cpu_seconds
(count)
Total amount of CPU used by SQL pods
Shown as second
crdb_cloud.tenant.sql_usage.pgwire_egress_bytes
(count)
Total number of bytes transferred from a SQL pod to the client
Shown as unit
crdb_cloud.tenant.sql_usage.external_io_ingress_bytes
(count)
Total number of bytes read from external services such as cloud storage providers
Shown as byte
crdb_cloud.tenant.sql_usage.external_io_egress_bytes
(count)
Total number of bytes written to external services such as cloud storage providers
Shown as byte
crdb_cloud.tenant.sql_usage.cross_region_network_ru
(count)
Total number of RUs charged for cross-region network traffic
Shown as unit
crdb_cloud.storage_bytes
(count)
The amount of data being stored in the cluster. This is the logical number of live bytes and does not account for compression or replication.
Shown as byte

ヘルプ

CockroachDB Dedicated インテグレーションには、サービスのチェック機能は含まれません。

ヘルプ

CockroachDB Dedicated インテグレーションには、イベントは含まれません。

Agent

ご不明な点は、Datadog のサポートチームまでお問合せください。