Skip to main content

All OpenBao telemetry metrics

For completeness, we provide a full list of available metrics below in alphabetic order by name.

Full metric list

database.Close

Metric typeValueDescription
summarymsTime required to close a database secret engine (across all database secrets engines)

database.Close.error

Metric typeValueDescription
counternumberNumber of errors encountered across all database secrets engines while closing database connections

database.CreateUser

Metric typeValueDescription
summarymsTime required to create a user across all database secrets engines

database.CreateUser.error

Metric typeValueDescription
counternumberNumber of errors encountered across all database secrets engines while creating users

database.Initialize

Metric typeValueDescription
summarymsTime required to initialize a database secret engine (across all database secrets engines)

database.Initialize.error

Metric typeValueDescription
counternumberNumber of errors encountered across all database secrets engines while initializing the database

database.{NAME}.Close

Metric typeValueDescription
summarymsTime required to close the database secrets engine {NAME}

database.{NAME}.Close.error

Metric typeValueDescription
counternumberNumber of errors encountered for the named database secrets engines while closing database connections

database.{NAME}.CreateUser

Metric typeValueDescription
summarymsTime required to create a user for the named database secrets engine

database.{NAME}.CreateUser.error

Metric typeValueDescription
counternumberNumber of errors encountered for the named database secrets engines while creating users

database.{NAME}.Initialize

Metric typeValueDescription
summarymsTime required to initialize a database secret engine for the named database

database.{NAME}.Initialize.error

Metric typeValueDescription
counternumberNumber of errors encountered for the named database secrets engines while initializing the database

database.{NAME}.RenewUser

Metric typeValueDescription
summarymsTime required to renew a user for the named database secrets engine

database.{NAME}.RenewUser.error

Metric typeValueDescription
counternumberNumber of errors encountered for the named database secrets engines while renewing users

database.{NAME}.RevokeUser

Metric typeValueDescription
summarymsTime required to revoke a user for the named database secrets engine

database.{NAME}.RevokeUser.error

Metric typeValueDescription
counternumberNumber of errors encountered for the named database secrets engines while revoking users

database.RenewUser

Metric typeValueDescription
summarymsTime required to renew a user across all database secrets engines

database.RenewUser.error

Metric typeValueDescription
counternumberNumber of errors encountered across all database secrets engines while renewing users

database.RevokeUser

Metric typeValueDescription
summarymsTime required to revoke a user across all database secrets engines

database.RevokeUser.error

Metric typeValueDescription
counternumberNumber of errors encountered across all database secrets engines while revoking users

secrets.pki.tidy.cert_store_current_entry

Metric typeValueDescription
gaugenumberIndex of the certificate store entry currently being verified by the tidy operation

secrets.pki.tidy.cert_store_deleted_count

Metric typeValueDescription
counternumberNumber of entries deleted from the certificate store

secrets.pki.tidy.cert_store_total_entries_remaining

Metric typeValueDescription
gaugenumberNumber of entries in the certificate store checked, but not removed, during the tidy operation

secrets.pki.tidy.cert_store_total_entries

Metric typeValueDescription
gaugenumberNumber of entries in the certificate store to verify during the tidy operation

secrets.pki.tidy.duration

Metric typeValueDescription
summarymsTime required to complete the PKI tidy operation

secrets.pki.tidy.failure

Metric typeValueDescription
counternumberNumber of times the PKI tidy operation failed to finish due to errors

secrets.pki.tidy.revoked_cert_current_entry

Metric typeValueDescription
gaugenumberIndex of the revoked certificate store entry currently being verified by the tidy operation

secrets.pki.tidy.revoked_cert_deleted_count

Metric typeValueDescription
counternumberNumber of entries deleted from the certificate store for revoked certificates

secrets.pki.tidy.revoked_cert_total_entries_fixed_issuers

Metric typeValueDescription
gaugenumberNumber of entries in the certificate store found to have incorrect issuer information that were fixed during the tidy operation

secrets.pki.tidy.revoked_cert_total_entries_incorrect_issuers

Metric typeValueDescription
gaugenumberTotal number of entries in the certificate store found to have incorrect issuer information

secrets.pki.tidy.revoked_cert_total_entries_remaining

Metric typeValueDescription
gaugenumberNumber of revoked certificates in the certificate store checked, but not removed, during the tidy operation

secrets.pki.tidy.revoked_cert_total_entries

Metric typeValueDescription
gaugenumberNumber of revoked certificate entries in the certificate store to be verified during the tidy operation

secrets.pki.tidy.start_time_epoch

Metric typeValueDescription
gaugesecondsEpoch time (seconds since 1970-01-01) when the PKI tidy operation began

The start time metric reports a value of 0 if the PKI tidy operation is not currently active.

secrets.pki.tidy.success

Metric typeValueDescription
counternumberNumber of times the PKI tidy operation completed successfully

vault.audit.{DEVICE}.log_request_failure

Metric typeValueDescription
counternumberNumber of audit log request failures

vault.audit.{DEVICE}.log_request

Metric typeValueDescription
summarymsTime required to complete all audit log requests across the device

vault.audit.{DEVICE}.log_response_failure

Metric typeValueDescription
counternumberNumber of audit log request failures

vault.audit.{DEVICE}.log_response

Metric typeValueDescription
summarymsTime required to complete all audit log responses across the device

vault.audit.log_request_failure

Metric typeValueDescription
counternumberNumber of audit log request failures across all devices

The number of request failures is a crucial metric.

A non-zero value for vault.audit.log_request_failure indicates that all your configured audit devices failed to log a request (or response). If OpenBao cannot properly audit a request, or the response to a request, the original request will fail.

Refer to the OpenBao logs and any device-specific metrics to troubleshoot the failing audit log device.

vault.audit.log_request

Metric typeValueDescription
summarymsTime required to complete all audit log requests across all audit log devices

vault.audit.log_response_failure

Metric typeValueDescription
counternumberNumber of audit log request failures across all devices

The number of request failures is a crucial metric.

A non-zero value for vault.audit.log_response_failure indicates that one of the configured audit log devices failed to respond to OpenBao. If OpenBao cannot properly audit a request, or the response to a request, the original request will fail.

Refer to the device-specific metrics and logs to troubleshoot the failing audit log device.

vault.audit.log_response

Metric typeValueDescription
summarymsTime required to complete audit log responses across all audit log devices

vault.autopilot.failure_tolerance

Metric typeValueDescription
gaugenodesThe number of healthy nodes in excess of quorum

The failure tolerance indicates how many currently healthy nodes can fail without losing quorum.

vault.autopilot.healthy

Metric typeValueDescription
gaugebooleanIndicates whether all nodes are healthy
  • A value of 1 on the gauge means that Autopilot deems all nodes healthy.
  • A value of 0 on the gauge means that Autopilot deems at least 1 node unhealthy.

vault.autopilot.node.healthy

Metric typeValueDescription
gaugebooleanIndicates whether the active node is healthy
  • A value of 1 on the gauge means that Autopilot deems the node indicated by node_id is healthy.
  • A value of 0 on the gauge means that Autopilot cannot communicate with the node indicated by node_id, or deems the node unhealthy.

vault.barrier.delete

Metric typeValueDescription
summarymsTime required to complete a DELETE operation at the barrier

vault.barrier.get

Metric typeValueDescription
summarymsTime required to complete a GET operation at the barrier

vault.barrier.list

Metric typeValueDescription
summarymsTime required to complete a LIST operation at the barrier

vault.barrier.put

Metric typeValueDescription
summarymsTime required to complete a PUT operation at the barrier

vault.cache.delete

Metric typeValueDescription
counternumberNumber of deletes from the LRU cache

vault.cache.hit

Metric typeValueDescription
counternumberNumber of hits against the LRU cache that avoided a read from configured storage

vault.cache.miss

Metric typeValueDescription
counternumberNumber of misses against the LRU cache that required a read from configured storage

vault.cache.write

Metric typeValueDescription
counternumberNumber of writes to the LRU cache

vault.core.active

Metric typeValueDescription
gaugebooleanIndicates whether the OpenBao node is active
  • A value of 1 indicates that the node is active.
  • A value of 0 indicates that the node is in standby.

vault.core.check_token

Metric typeValueDescription
summarymsTime required to complete a token check

vault.core.fetch_acl_and_token

Metric typeValueDescription
summarymsTime required to fetch ACL and token entries

vault.core.handle_login_request

Metric typeValueDescription
summarymsTime required to complete a login request

vault.core.handle_request

Metric typeValueDescription
summarymsTime required to complete a non-login request

vault.core.in_flight_requests

Metric typeValueDescription
gaugerequestsNumber of requests currently in progress

vault.core.leadership_lost

Metric typeValueDescription
summarymsTotal time that a high-availability cluster node last maintained leadership

Leadership time updates occur whenever leadership changes. Frequent updates to vault.core.leadership_lost with low leadership times indicates flapping as leader status rotates between nodes.

vault.core.leadership_setup_failed

Metric typeValueDescription
summarymsTime taken by the most recent leadership setup failure

Setup failure time is an important health metric for your high-availability OpenBao installation. We strongly recommend that you closely monitor vault.core.leadership_setup_failed and set alerts that keep you informed of the overall cluster leadership status.

vault.core.license.expiration_time_epoch

Metric typeValueDescription
gaugetimestampEpoch time (seconds since 1970-01-01) at which the license will expire

vault.core.locked_users

Metric typeValueDescription
gaugeusersThe number of users currently locked out of OpenBao

The number of locked users refreshes every 15 minutes.

vault.core.mount_table.num_entries

Metric typeValueDescription
gaugeobjectsNumber of mounts in the given mount table

Mountpoint count metrics include labels to indicate whether the relevant table is an authentication table or a logical table and whether the table is replicated or local.

vault.core.mount_table.size

Metric typeValueDescription
gaugebytesThe current size of the relevant mount table.

Table size metrics include labels to indicate whether the relevant table is an authentication table or a logical table and whether the table is replicated or local.

vault.core.post_unseal

Metric typeValueDescription
summarymsTime required to complete post-unseal operations

vault.core.pre_seal

Metric typeValueDescription
summarymsTime required to complete pre-seal operations

vault.core.seal-internal

Metric typeValueDescription
summarymsTime required to complete internal OpenBao seal operations

vault.core.seal-with-request

Metric typeValueDescription
summarymsTime required to complete seal operations that were triggered by explicit request

vault.core.step_down

Metric typeValueDescription
summarymsTime required to step down cluster leadership

vault.core.unseal

Metric typeValueDescription
summarymsTime required to complete unseal operations

vault.core.unsealed

Metric typeValueDescription
gaugebooleanIndicates whether OpenBao is currently unsealed
  • A value of 1 indicates OpenBao is currently unsealed and clients can read secrets.
  • A value of 0 indicates OpenBao is currently sealed and clients cannot read secrets.

vault.expire.fetch-lease-times-by-token

Metric typeValueDescription
summarymsTime taken to retrieve lease times by token

vault.expire.fetch-lease-times

Metric typeValueDescription
summarymsTime taken to retrieve lease times

vault.expire.job_manager.queue_length

Metric typeValueDescription
summaryleasesThe total number of pending revocation jobs by queue_id

The queue ID in the queue_id label indicates the mount accessor associated with the expiring lease. For example, the secrets engine or authentication method.

vault.expire.job_manager.total_jobs

Metric typeValueDescription
summaryleasesThe total number of pending revocation jobs

vault.expire.lease_expiration

Metric typeValueDescription
counternumberThe number of lease expirations to date

vault.expire.lease_expiration.error

Metric typeValueDescription
counternumberThe total number of lease expiration errors

vault.expire.lease_expiration.time_in_queue

Metric typeValueDescription
summarymsTime taken for a lease to get to the front of the revoke queue

vault.expire.leases.by_expiration

Metric typeValueDescription
gaugeleasesThe number of leases set to expire, grouped by the configured interval

The relevant time intervals are defined in the telemetry stanza for your OpenBao server configuration with the following parameters:

  • lease_metrics_epsilon: 1 hour (default)
  • num_lease_metrics_buckets: 168 hours (default)
  • add_lease_metrics_namespace_labels: false (default)

OpenBao reports the number of leases due to expire every lease_metrics_epsilon interval in the time period current_time + num_lease_metrics_buckets.

vault.expire.num_irrevocable_leases

Metric typeValueDescription
gaugeleasesThe number of leases that cannot be automatically revoked

vault.expire.num_leases

Metric typeValueDescription
gaugeleasesThe total number of leases eligible for eventual expiry

vault.expire.register-auth

Metric typeValueDescription
summarymsTime taken to register leases associated with new service tokens

vault.expire.register

Metric typeValueDescription
summarymsTime taken for register operations

vault.expire.renew-token

Metric typeValueDescription
summarymsTime taken to renew a token

vault.expire.renew

Metric typeValueDescription
summarymsTime taken to renew a lease

vault.expire.revoke-by-token

Metric typeValueDescription
summarymsTime taken to revoke all secrets issued with a given token

vault.expire.revoke-force

Metric typeValueDescription
summarymsTime taken to forcibly revoke a token

vault.expire.revoke-prefix

Metric typeValueDescription
summarymsTime taken to revoke all tokens on a prefix

vault.expire.revoke

Metric typeValueDescription
summarymsTime taken to revoke a token

vault.ha.rpc.client.echo

Metric typeValueDescription
summarymsTime taken to send an echo request from a standby to the active node (also emitted by perf standbys)

vault.ha.rpc.client.echo.errors

Metric typeValueDescription
counternumberNumber of standby echo request failures (also emitted by perf standbys)

vault.ha.rpc.client.forward

Metric typeValueDescription
summarymsTime taken to forward a request from a standby to the active node

vault.ha.rpc.client.forward.errors

Metric typeValueDescription
counternumberNumber of standby request forwarding failures

vault.identity.entity.alias.count

Metric typeValueDescription
gaugealiasesThe number of identity entities aliases (per authN mount) currently stored in OpenBao

OpenBao updates the alias count every usage_guage_period interval.

vault.identity.entity.count

Metric typeValueDescription
gaugeentitiesThe number of identity entity aliases (per namespace) currently stored in OpenBao

vault.identity.entity.creation

Metric typeValueDescription
counternumberThe number of identity entities created per namespace

vault.identity.num_entities

Metric typeValueDescription
gaugeentitiesThe total number of identity entities currently stored in OpenBao

vault.identity.upsert_entity_txn

Metric typeValueDescription
summarymsTime required to upsert an entity to the in-memory database and, on the active node, persist the data to storage

vault.identity.upsert_group_txn

Metric typeValueDescription
summarymsTime required to upsert group membership to the in-memory database and, on the active node, persist the data to storage

vault.logshipper.buffer.length

Metric typeValueDescription
gaugebuffer entriesCurrent length of the log shipper buffer

vault.logshipper.buffer.max_length

Metric typeValueDescription
gaugebuffer entriesMaximum length of the log shipper buffer seen to date

vault.logshipper.buffer.max_size

Metric typeValueDescription
gaugebytesMaximum allowable size of the log shipper buffer

vault.logshipper.buffer.size

Metric typeValueDescription
gaugebytesCurrent size of the log shipper buffer

vault.logshipper.streamWALs.guard_found

Metric typeValueDescription
counternumberNumber of times OpenBao began streaming WAL entires and found a starting index in the merkle tree

vault.logshipper.streamWALs.missing_guard

Metric typeValueDescription
counternumberNumber of times OpenBao began streaming WAL entires without finding a starting index in the Merkle tree

vault.logshipper.streamWALs.scanned_entries

Metric typeValueDescription
summaryentriesNumber of entries scanned in the buffer before OpenBao found the correct entry

vault.merkle.flushDirty

Metric typeValueDescription
summarymsThe average time required to flush dirty pages to storage

vault.merkle.flushDirty.num_pages

Metric typeValueDescription
gaugepagesNumber of pages flushed

vault.merkle.flushDirty.outstanding_pages

Metric typeValueDescription
gaugepagesNumber of dirty pages waiting to be flushed

vault.merkle.saveCheckpoint

Metric typeValueDescription
summarymsThe average time required to save a checkpoint

vault.merkle.saveCheckpoint.num_dirty

Metric typeValueDescription
gaugepagesNumber of dirty pages at checkpoint

vault.metrics.collection

Metric typeValueDescription
summarymsThe average time required (per gauge type) to collect usage data

vault.metrics.collection.error

Metric typeValueDescription
counternumberThe total number of errors (per gauge type) that OpenBao encountered while collecting usage data

vault.metrics.collection.interval

Metric typeUnitsDescription
summarytime durationThe current value of usage_gauge_period

vault.policy.delete_policy

Metric typeValueDescription
summarymsTime required to delete a policy

vault.policy.get_policy

Metric typeValueDescription
summarymsTime required to read a policy

vault.policy.list_policies

Metric typeValueDescription
summarymsTime required to list all policies

vault.policy.set_policy

Metric typeValueDescription
summarymsTime required to set a policy

vault.quota.lease_count.counter

Metric typeValueDescription
gaugeleaseTotal number of leases associated with the named quota rule

The number of leases reported is specific to the quota rule listed in the name label, not the number of leases in general. For example, if the named rule allows for 50 leases max and there are currently 40 leases in the scope of that quota rule, the value of vault.quota.lease_count.counter is 40 even if there are 1000 other leases that are unscoped or in the scope of other quota rules.

vault.quota.lease_count.max

Metric typeValueDescription
gaugeleaseMaximum number of leases allowed by the named quota rule

vault.quota.lease_count.violation

Metric typeValueDescription
counternumberNumber of requests rejected due to exceeding the named lease count quota

vault.quota.rate_limit.violation

Metric typeValueDescription
counternumberNumber of requests rejected due to exceeding the named rate limit quota rule

vault.raft_storage.bolt.cursor.count

Metric typeValueDescription
gaugenumberNumber of cursors created in the Bolt database

vault.raft_storage.bolt.freelist.allocated_bytes

Metric typeValueDescription
gaugebytesTotal space allocated for the freelist for the Bolt database

vault.raft_storage.bolt.freelist.free_pages

Metric typeValueDescription
gaugenumberNumber of free pages in the freelist for the Bolt database

vault.raft_storage.bolt.freelist.pending_pages

Metric typeValueDescription
gaugenumberNumber of pending pages in the freelist for the Bolt database

vault.raft_storage.bolt.freelist.used_bytes

Metric typeValueDescription
gaugebytesTotal space used by the freelist for the Bolt database

vault.raft_storage.bolt.node.count

Metric typeValueDescription
gaugenumberNumber of node allocations for the Bolt database

vault.raft_storage.bolt.node.dereferences

Metric typeValueDescription
gaugenumberTotal number of node dereferences by the Bolt database

vault.raft_storage.bolt.page.bytes_allocated

Metric typeValueDescription
gaugebytesTotal space allocated to the Bolt database

vault.raft_storage.bolt.page.count

Metric typeValueDescription
gaugenumberNumber of page allocations in the Bolt database

vault.raft_storage.bolt.rebalance.count

Metric typeValueDescription
gaugenumberNumber of node rebalances performed by the Bolt database

vault.raft_storage.bolt.rebalance.time

Metric typeValueDescription
summarymsTime required by the Bolt database to rebalance nodes

vault.raft_storage.bolt.spill.count

Metric typeValueDescription
gaugenumberNumber of nodes spilled by the Bolt database

vault.raft_storage.bolt.spill.time

Metric typeValueDescription
summarymsTotal time spent spilling by the Bolt database

vault.raft_storage.bolt.split.count

Metric typeValueDescription
gaugenumberNumber of nodes split by the Bolt database

vault.raft_storage.bolt.transaction.currently_open_read_transactions

Metric typeValueDescription
gaugenumberNumber of in-process read transactions for the Bolt DB

vault.raft_storage.bolt.transaction.started_read_transactions

Metric typeValueDescription
gaugenumberNumber of read transactions started by the Bolt DB

vault.raft_storage.bolt.write.count

Metric typeValueDescription
gaugenumberNumber of writes performed by the Bolt database

vault.raft_storage.bolt.write.time

Metric typeValueDescription
countermsTotal cumulative time the Bolt database has spent writing to disk.

vault.raft_storage.follower.applied_index_delta

Metric typeValueDescription
gaugenumberThe difference between the index applied by the leader and the index applied by the follower as reported by echoes

vault.raft_storage.follower.last_heartbeat_ms

Metric typeValueDescription
gaugemsTime since the follower last received a heartbeat request

vault.raft_storage.stats.applied_index

Metric typeValueDescription
gaugenumberHighest index of raft log last applied to the finite state machine or added to fsm_pending queue

vault.raft_storage.stats.commit_index

Metric typeValueDescription
gaugenumberIndex of the last raft log committed to disk on the node

vault.raft_storage.stats.fsm_pending

Metric typeValueDescription
gaugenumberNumber of raft logs queued by the node for the finite state machine to apply

vault.raft-storage.delete

Metric typeValueDescription
timermsTime required to insert log entry to delete path

vault.raft-storage.entry_size

Metric typeValueDescription
summarybytesThe total size of a raft entry during log application

vault.raft-storage.get

Metric typeValueDescription
timermsTime required to retrieve a value for the given path from the finite state machine

vault.raft-storage.list

Metric typeValueDescription
timermsTime required to list all entries under the prefix from the finite state machine

vault.raft-storage.put

Metric typeValueDescription
timermsTime required to insert a log entry to the persist path

vault.raft-storage.transaction

Metric typeValueDescription
timermsTime required to insert operations into a single log

vault.raft.apply

Metric typeValueDescription
counternumberNumber of transactions in the configured interval

The vault.raft.apply metric is generally a good indicator of the write load on your raft internal storage.

vault.raft.barrier

Metric typeValueDescription
counternumberNumber of times the node started the barrier

A node starts the barrier by issuing a blocking call when it wants to ensure that all pending operations that need to be applied to the finite state machine are properly queued.

vault.raft.candidate.electSelf

Metric typeValueDescription
summarymsTime required for a node to send a vote request to a peer

vault.raft.commitNumLogs

Metric typeValueDescription
gaugenumberNumber of logs processed for application to the finite state machine in a single batch

vault.raft.commitTime

Metric typeValueDescription
summarymsTime required to commit a new entry to the raft log on the leader node

vault.raft.compactLogs

Metric typeValueDescription
summarymsTime required to trim unnecessary logs

vault.raft.fsm.apply

Metric typeValueDescription
summarynumberNumber of logs committed by the finite state machine since the last interval

vault.raft.fsm.applyBatch

Metric typeValueDescription
summarymsTime required by the finite state machine to apply the most recent batch of logs

vault.raft.fsm.applyBatchNum

Metric typeValueDescription
counternumberNumber of logs applied in the most recent batch

vault.raft.fsm.enqueue

Metric typeValueDescription
summarymsTime required to queue up a batch of logs for the finite state machine to apply

vault.raft.fsm.restore

Metric typeValueDescription
summarymsTime required by the finite state machine to complete a restore operation from a snapshot

vault.raft.fsm.snapshot

Metric typeValueDescription
summarymsTime required by the finite state machine to record state information for the current snapshot

vault.raft.fsm.store_config

Metric typeValueDescription
summarymsTime required to store the most recent raft configuration

vault.raft.get

Metric typeValueDescription
summarymsTime required to retrieve an entry from underlying storage

vault.raft.leader.dispatchLog

Metric typeValueDescription
timermsTime required for the leader node to write a log entry to disk

vault.raft.leader.dispatchNumLogs

Metric typeValueDescription
gaugenumberNumber of logs committed to disk in the most recent batch

vault.raft.leader.lastContact

Metric typeValueDescription
summarymsTime since the leader was last able to contact the follower nodes when checking its leader lease

vault.raft.list

Metric typeValueDescription
summarymsTime required to retrieve a list of keys from underlying storage

vault.raft.peers

Metric typeValueDescription
guagenumberThe number of peers in the raft cluster configuration

vault.raft.replication.appendEntries.log

Metric typeValueDescription
summarynumberNumber of logs replicated to a node to establish parity with leader logs

vault.raft.replication.appendEntries.rpc

Metric typeValueDescription
timermsTime required to replicate leader node log entries to all follower nodes with appendEntries

vault.raft.replication.heartbeat

Metric typeValueDescription
timermsTime required to invoke appendEntries on a peer so the peer does not time out

vault.raft.replication.installSnapshot

Metric typeValueDescription
timermsTime required to process an installSnapshot RPC call

Only nodes currently in the follower state report vault.raft.replication.installSnapshot metrics.

vault.raft.restore

Metric typeValueDescription
counternumberNumber of times that the node performed a restore operation

In the context of raft storage, a restore operation refers to the process where raft consumes an external snapshot to restore its state.

vault.raft.restoreUserSnapshot

Metric typeValueDescription
timermsTime required to restore the finite state machine from a user snapshot

vault.raft.rpc.appendEntries

Metric typeValueDescription
timermsTime required to process a remote appendEntries call from a node

vault.raft.rpc.appendEntries.processLogs

Metric typeValueDescription
timermsTime required to completely process the outstanding logs for the given node

vault.raft.rpc.appendEntries.storeLogs

Metric typeValueDescription
timermsTime required to record any outstanding logs since the last request to append entries for the given node

vault.raft.rpc.installSnapshot

Metric typeValueDescription
timermsTime required to process an installSnapshot RPC call

Only nodes currently in the follower state report vault.raft.rpc.installSnapshot metrics.

vault.raft.rpc.processHeartbeat

Metric typeValueDescription
timermsTime required to process a heartbeat request

vault.raft.rpc.requestVote

Metric typeValueDescription
summarymsTime required to complete a requestVote call

vault.raft.snapshot.create

Metric typeValueDescription
timermsTime required to capture a new snapshot

vault.raft.snapshot.persist

Metric typeValueDescription
timermsTime required to record snapshot meta information to disk while taking snapshots

vault.raft.snapshot.takeSnapshot

Metric typeValueDescription
timermsTotal time required to create and persist the current snapshot

In most cases, vault.raft.snapshot.takeSnapshot is approximately equal to vault.raft.snapshot.create + vault.raft.snapshot.persist.

vault.raft.state.candidate

Metric typeValueDescription
counternumberNumber of times the raft server initiated an election

vault.raft.state.follower

Metric typeValueDescription
summarynumberNumber of times in the configured interval that the raft server became a follower

Nodes transition to follower state under the following conditions:

  • when the node joins the cluster
  • when a leader is elected, but the node was not elected leader

vault.raft.state.leader

Metric typeValueDescription
counternumberNumber of times the raft server became a leader

vault.raft.transition.heartbeat_timeout

Metric typeValueDescription
summarynumberNumber of times that the node transitioned to candidate state after not receiving a heartbeat message from the last known leader

vault.raft.transition.leader_lease_timeout

Metric typeValueDescription
counternumberThe number of times the leader could not contact a quorum of nodes and therefore stepped down

vault.raft.verify_leader

Metric typeValueDescription
counternumberNumber of times in the configured interval that the node confirmed it is still the leader

vault.rollback.attempt.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to perform a rollback operation on the given mount point

vault.rollback.inflight

Metric typeValueDescription
gaugenumberNumber of rollback operations inflight

vault.rollback.queued

Metric typeValueDescription
guagenumberThe number of rollback operations waiting to be started

vault.rollback.waiting

Metric typeValueDescription
summarymsTime between queueing a rollback operation and the operation starting

vault.route.create.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to send a create request to the backend and for the backend to complete the operation for the given mount point

vault.route.delete.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to send a delete request to the backend and for the backend to complete the operation for the given mount point

vault.route.list.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to send a list request to the backend and for the backend to complete the operation for the given mount point

vault.route.read.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to send a read request to the backend and for the backend to complete the operation for the given mount point

vault.route.rollback.{MOUNTPOINT}

Metric typeValueDescription
summarymsTime required to send a rollback request to the backend and for the backend to complete the operation for the given mount point

OpenBao automatically schedules and performs mount point rollback operations to clean up partial errors.

vault.runtime.alloc_bytes

Metric typeValueDescription
gaugebytesSpace currently allocated to OpenBao processes

The number of allocated bytes may peak from time to time, but should always return to a steady state value in a health OpenBao installation.

vault.runtime.free_count

Metric typeValueDescription
gaugenumberNumber of freed objects

vault.runtime.gc_pause_ns

Metric typeValueDescription
summarynsTime required to complete the last garbage collection run

vault.runtime.heap_objects

Metric typeValueDescription
gaugenumberTotal number of objects on the heap in memory

The vault.runtime.heap_objects metric is a good memory pressure indicator. We recommend monitoring vault.runtime.heap_objects to establish an accurate baseline and thresholds for alerting on the health of your OpenBao installation.

vault.runtime.malloc_count

Metric typeValueDescription
gaugenumberTotal number of allocated heap objects in memory

vault.runtime.num_goroutines

Metric typeValueDescription
gaugenumberTotal number of Go routines running in memory

The vault.runtime.num_goroutines metric is a good system load indicator. We recommend monitoring vault.runtime.num_goroutines to establish an accurate baseline and thresholds for alerting on the health of your OpenBao installation.

vault.runtime.sys_bytes

Metric typeValueDescription
gaugenumberTotal number of bytes allocated to OpenBao

The total number of allocated system bytes includes space currently used by the heap plus space that has been reclaimed by, but not returned to, the operating system.

vault.runtime.total_gc_pause_ns

Metric typeValueDescription
gaugensThe total garbage collector pause time since OpenBao was last started

vault.runtime.total_gc_runs

Metric typeValueDescription
gaugenumberThe total number of garbage collection runs since OpenBao was last started

vault.secret.kv.count

Metric typeValueDescription
gaugenumberNumber of entries in each key-value secrets engines

OpenBao organizes the key-value pair count by cluster, namespace, and mount point.

vault.secret.lease.creation

Metric typeValueDescription
counternumberNumber of leases created by secrets engines

OpenBao organizes the lease count by cluster, namespace, secret engine, mount point, and time to live (TTL).

vault.token.count

Metric typeValueDescription
gaugenumberNumber of un-expired and un-revoked tokens available for use in the token store

OpenBao updates the token count every 10 minutes organizes the result by cluster and namespace.

vault.token.count.by_auth

Metric typeValueDescription
gaugenumberTotal number of service tokens created by a particular auth method

OpenBao organizes the token count by cluster, namespace, and authentication method.

vault.token.count.by_policy

Metric typeValueDescription
gaugenumberTotal number of service tokens with a particular policy attached

OpenBao organizes the token count by cluster, namespace, and policy. Tokens with more than one policy attached appear in the gauge for each associated policy.

vault.token.count.by_ttl

Metric typeValueDescription
gaugenumberTotal number of service tokens assigned a particular time to live (TTL)

OpenBao organizes the token count by cluster, namespace, and the TTL range assigned at creation.

vault.token.create_root

Metric typeValueDescription
counternumberNumber of root tokens created

The vault.token.create_root counts the total number of root tokens created over time, not the number of root tokens currently in use. As a result, the value of vault.token.create_root does not decrease when a root token is revoked.

vault.token.create

Metric typeValueDescription
summarymsTime required to create a token in OpenBao

vault.token.createAccessor

Metric typeValueDescription
summarymsTime required to create a token accessor in OpenBao

vault.token.creation

Metric typeValueDescription
counternumberNumber of service or batch tokens created

OpenBao organizes the creation count by cluster, namespace, authentication method, mount point, time to live (TTL), and token type.

vault.token.lookup

Metric typeValueDescription
summarymsTime required to look up a token in OpenBao

vault.token.revoke-tree

Metric typeValueDescription
summarymsTime required to fully revoke a token tree in OpenBao

vault.token.revoke

Metric typeValueDescription
summarymsTime required to revoke a token in OpenBao

vault.token.store

Metric typeValueDescription
summarymsTime required to store an updated token entry without writing to the secondary index

vault.wal.deleteWALs

Metric typeValueDescription
summarymsTime required to fully delete a write-ahead log

vault.wal.flushReady

Metric typeValueDescription
summarymsTime required to fully flush a write-ahead log that is ready for storage

vault.wal.flushReady.queue_len

Metric typeValueDescription
summarynumberCurrent size of the write queue in the WAL system

vault.wal.gc.deleted

Metric typeValueDescription
gaugenumberNumber of write-ahead logs deleted during garbage collection

vault.wal.gc.total

Metric typeValueDescription
gaugenumberTotal number of write-ahead logs currently on disk

vault.wal.loadWAL

Metric typeValueDescription
summarymsTime required to load a write-ahead log

vault.wal.persistWALs

Metric typeValueDescription
summarymsTime required to persist a write-ahead log