A newer version of this documentation is available.

View Latest

Data Service Metrics

      +
      A list of the metrics provided by the Data Service.

      The following Data Service metrics can be queried by means of the REST APIs described in Statistics.

      Tip
      • The x.y.z badge shows the Couchbase Server version the metric was added in.

      • The type / unit badge shows shows the Prometheus type and unit (if present).

      kv_audit_dropped_events     7.0.0 counter

      The number of audit events dropped due to errors while trying to insert them to the audit trail

      kv_audit_enabled     7.0.0 gauge

      Boolean value to indicate if audit is enabled or not

      kv_auth_cmds     7.0.0 gauge

      The number of authentication commands

      kv_auth_errors     7.0.0 gauge

      The number of failed authentication requests

      kv_bg_batch_size     7.0.0 histogram

      Batch size for background fetches

      kv_bg_load_seconds     7.0.0 histogram / seconds

      Background fetches waiting for disk

      kv_bg_wait_seconds     7.0.0 histogram / seconds

      Background fetches waiting in the dispatcher queue

      kv_cmd_duration_seconds     7.0.0 histogram / seconds

      Per-opcode histogram of time taken to execute operations

      kv_cmd_lookup     7.0.0 counter

      The number of lookup operations

      kv_cmd_lookup_10s_count     7.0.0 gauge

      The number of lookup operations performed within the last 10 seconds

      kv_cmd_lookup_10s_duration_seconds     7.0.0 gauge / seconds

      The total duration of lookup operations performed over the last 10 seconds

      kv_cmd_mutation     7.0.0 counter

      The number of mutation operations

      kv_cmd_mutation_10s_count     7.0.0 gauge

      The number of mutation operations performed within the last 10 seconds

      kv_cmd_mutation_10s_duration_seconds     7.0.0 gauge / seconds

      The total duration of mutation operations performed over the last 10 seconds

      kv_cmd_total_gets     7.0.0 counter

      The total number of data retrieval operations (all buckets)

      kv_cmd_total_ops     7.0.0 counter

      The sum of cmd_total_sets and cmd_total_gets (all buckets)

      kv_cmd_total_sets     7.0.0 counter

      The total number of mutation operations (all buckets)

      kv_collection_data_size_bytes     7.0.0 gauge / bytes

      Per-collection data size on disk

      kv_collection_history     7.2.0 gauge

      Whether history (CDC) is enabled for each collection

      kv_collection_item_count     7.0.0 gauge

      Per-collection item count

      kv_collection_maxTTL_seconds     7.0.0 gauge / seconds

      Per-collection maxTTL (maximum expiry) if configured

      kv_collection_mem_used_bytes     7.0.0 gauge / bytes

      Per-collection memory usage

      kv_collection_ops     7.0.0 counter

      Per-collection counters of sets/gets/deletes

      kv_conflicts_resolved     7.2.0 counter

      Counter of all SetWithMeta/DelWithMeta conflict resolution results. The result may be that the incoming operation was: accepted as it is 'ahead', rejected as it is 'behind', or rejected as it appears identical (by metadata, not comparing document bodies)

      kv_conn_yields     7.0.0 counter

      The total number all clients in this bucket yield due to consuming the number of ops allowed for the current timeslice

      kv_connection_recycle_high_watermark     7.2.0 gauge

      Number (or percentage of total available) connections allowed before KV will begin to close older connections to avoid reaching the limit

      kv_connection_structures     7.0.0 gauge

      Current number of allocated connection structures

      kv_curr_connections     7.0.0 gauge

      The current number of connections. This includes user, system and daemon connections

      kv_curr_items     7.0.0 gauge

      Count of alive (non-deleted) items in active vbuckets, including non-resident items

      kv_curr_items_tot     7.0.0 gauge

      Total number of items

      kv_curr_temp_items     7.0.0 gauge

      Number of temporary items in memory

      kv_daemon_connections     7.0.0 gauge

      The number of server sockets currently in use

      kv_daemon_memory_allocated_bytes     7.1.0 gauge / bytes

      Total amount of memory allocated (outside the context of a bucket)

      kv_daemon_memory_resident_bytes     7.1.0 gauge / bytes

      Total amount of memory resident (outside the context of a bucket)

      kv_datatype_count     7.0.2 gauge

      Count of items in memory with a given datatype combination

      kv_dcp_backoff     7.0.0 gauge

      Number of times Consumer DCP connections (i.e., replica) have paused consuming items because memory usage is too high

      kv_dcp_connection_count     7.0.0 gauge

      Current number of DCP connections (Consumers or Producers)

      kv_dcp_count     7.0.0 gauge

      Current number of DCP connections

      kv_dcp_items_backfilled     7.2.1 gauge

      Number of items pushed into the DCP stream ready queue from a backfill

      kv_dcp_items_remaining     7.0.0 gauge

      Current total number of items remaining for to be sent for all outgoing DCP streams (approximate)

      kv_dcp_items_sent     7.0.0 gauge

      Total number of items sent out by all currently existing outgoing DCP streams, since each stream was created

      kv_dcp_max_running_backfills     7.0.2 gauge

      Maximum number of backfills across all DCP connections

      kv_dcp_num_running_backfills     7.0.2 gauge

      Total number of running backfills across all DCP connections

      kv_dcp_ready_queue_size_bytes     7.1.0 gauge / bytes

      Estimated memory usage of items waiting to be sent across all existing DCP connections

      kv_dcp_total_data_size_bytes     7.0.0 gauge / bytes

      Total data sent across all existing DCP connections

      kv_dcp_total_uncompressed_data_size_bytes     7.0.0 gauge / bytes

      Total equivalent uncompressed size of data sent across all existing DCP connections

      kv_disk_seconds     7.0.0 histogram / seconds

      time spent waiting for disk

      kv_domain_memory_used_bytes     7.1.0 gauge / bytes

      Current memory used in KV for primary/secondary domain

      kv_ep_access_scanner_enabled     7.0.0 gauge

      True if access scanner task is enabled

      kv_ep_access_scanner_last_runtime_seconds     7.0.0 gauge / seconds

      Number of seconds that last Access Scanner task run took to complete.

      kv_ep_access_scanner_num_items     7.0.0 gauge

      Number of items that last Access Scanner task run wrote to the Access Log.

      kv_ep_access_scanner_task_time     7.0.0 gauge

      Time of the next access scanner task (GMT), NOT_SCHEDULED if access scanner has been disabled

      kv_ep_ahead_exceptions     7.0.0 counter

      Total number of times a vbucket saw an item with a HLC CAS from too far in the future (indicating the clock is behind)

      kv_ep_allow_sanitize_value_in_deletion     7.0.0 gauge

      Let EPE delete/prepare/del_with_meta prune any invalid body in the payload instead of failing

      kv_ep_alog_block_size     7.0.0 gauge

      Logging block size.

      kv_ep_alog_max_stored_items     7.0.0 gauge

      kv_ep_alog_resident_ratio_threshold     7.0.0 gauge

      kv_ep_alog_sleep_time     7.0.0 gauge

      Number of minutes between each sweep for the access log

      kv_ep_alog_task_time     7.0.0 gauge

      Hour in GMT time when access scanner task is scheduled to run

      kv_ep_backfill_mem_threshold     7.0.0 gauge

      kv_ep_behind_exceptions     7.0.0 counter

      Total number of times a vbucket saw an item with a HLC CAS from too far in the past (indicating the clock is ahead)

      kv_ep_bfilter_enabled     7.0.0 gauge

      kv_ep_bfilter_fp_prob     7.0.0 gauge

      kv_ep_bfilter_key_count     7.0.0 gauge

      kv_ep_bfilter_residency_threshold     7.0.0 gauge

      kv_ep_bg_fetch_avg_read_amplification_ratio     7.0.0 gauge / ratio

      Average read amplification for all background fetch operations - ratio of read()s to documents fetched.

      kv_ep_bg_fetched     7.0.0 counter

      Number of items fetched from disk

      kv_ep_bg_fetched_compaction     7.1.5 counter

      The number of bgfetches which are triggered by compaction

      kv_ep_bg_load_avg_seconds     7.0.0 gauge / seconds

      The average time for an item to be loaded from disk

      kv_ep_bg_load_seconds     7.0.0 counter / seconds

      The total elapsed time for items to be loaded from disk

      kv_ep_bg_max_load_seconds     7.0.0 gauge / seconds

      The longest load time when loading from disk

      kv_ep_bg_max_wait_seconds     7.0.0 gauge / seconds

      The longest time in the queue waiting to be loaded from disk

      kv_ep_bg_meta_fetched     7.0.0 counter

      Number of metadata fetches from disk

      kv_ep_bg_min_load_seconds     7.0.0 gauge / seconds

      The shortest load time when loading from disk

      kv_ep_bg_min_wait_seconds     7.0.0 gauge / seconds

      The shortest time in the queue waiting to be loaded from disk

      kv_ep_bg_num_samples     7.0.0 gauge

      The number of samples included in the average

      kv_ep_bg_remaining_items     7.0.0 gauge

      Number of remaining bg fetch items

      kv_ep_bg_remaining_jobs     7.0.0 gauge

      Number of remaining bg fetch jobs

      kv_ep_bg_wait_avg_seconds     7.0.0 gauge / seconds

      The average wait time for an item before it's serviced by the dispatcher

      kv_ep_bg_wait_seconds     7.0.0 gauge / seconds

      The total elapse time for the wait queue

      kv_ep_blob_num     7.0.0 gauge

      The number of blob objects in the cache

      kv_ep_bucket_quota_change_task_poll_interval     7.0.0 gauge

      Time in seconds between the BucketQuotaChangeTask polling memory usage to attempt to reduce the bucket quota

      kv_ep_cache_size     7.0.0 gauge

      Memory quota (in bytes) for this bucket.

      kv_ep_checkpoint_computed_max_size_bytes     7.1.0 gauge / bytes

      Actual max size in bytes of a single Checkpoint

      kv_ep_checkpoint_destruction_tasks     7.0.0 gauge

      Number of tasks responsible for destroying closed unreferenced checkpoints.

      kv_ep_checkpoint_max_size     7.0.0 gauge

      Max size (in bytes) of a single checkpoint. '0' for EPEngine auto-setup.

      kv_ep_checkpoint_memory_bytes     7.0.0 gauge / bytes

      Memory of items in all checkpoints

      kv_ep_checkpoint_memory_pending_destruction_bytes     7.1.0 gauge / bytes

      Memory of checkpoint structures awaiting destruction by a background task

      kv_ep_checkpoint_memory_quota_bytes     7.1.0 gauge / bytes

      Max allocation allowed in all checkpoints

      kv_ep_checkpoint_memory_ratio     7.0.0 gauge

      Max ratio of the bucket quota that can be allocated in checkpoints. The system enters a TempOOM phase if hit.

      kv_ep_checkpoint_memory_recovery_lower_mark     7.0.0 gauge

      Fraction of the checkpoint quota (as computed by checkpoint_memory_ratio) that represents the target of checkpoint memory recovery. Memory recovery yields when reached.

      kv_ep_checkpoint_memory_recovery_lower_mark_bytes     7.1.0 gauge

      Fraction of the checkpoint quota (as computed by checkpoint_memory_ratio) that represents the target of checkpoint memory recovery. Memory recovery yields when reached

      kv_ep_checkpoint_memory_recovery_upper_mark     7.0.0 gauge

      Fraction of the checkpoint quota (as computed by checkpoint_memory_ratio) that triggers attempt of memory releasing from checkpoint.

      kv_ep_checkpoint_memory_recovery_upper_mark_bytes     7.1.0 gauge

      Fraction of the checkpoint quota (as computed by checkpoint_memory_ratio) that triggers attempt of memory releasing from checkpoint

      kv_ep_checkpoint_remover_task_count     7.0.0 gauge

      Number of concurrent tasks performing ItemExpel and CursorDrop/CheckpointRemoval

      kv_ep_chk_expel_enabled     7.0.0 gauge

      Enable the ability to expel (remove from memory) items from a checkpoint. An item can be expelled if all cursors in the checkpoint have iterated past the item.

      kv_ep_chk_persistence_remains     7.0.0 gauge

      Number of remaining vbuckets for checkpoint persistence

      kv_ep_chk_remover_stime     7.0.0 gauge

      kv_ep_clock_cas_drift_threshold_exceeded     7.0.0 gauge

      ep_active_ahead_exceptions + ep_replica_ahead_exceptions

      kv_ep_collections_drop_compaction_delay     7.0.0 gauge

      How many milliseconds before compaction runs following the drop of a collection

      kv_ep_collections_enabled     7.0.0 gauge

      Enable the collections functionality, enabling the storage of collection metadata

      kv_ep_commit_num     7.0.0 gauge

      Total number of write commits

      kv_ep_commit_time_seconds     7.0.0 gauge / seconds

      Number of milliseconds of most recent commit

      kv_ep_commit_time_total_seconds     7.0.0 gauge / seconds

      Cumulative milliseconds spent committing

      kv_ep_compaction_aborted     7.1.0 gauge

      Counter of how many times compaction aborted, e.g. the vbucket is required to rollback, so compaction is aborted

      kv_ep_compaction_expire_from_start     7.0.0 gauge

      Should compaction expire items that were logically deleted at the start of the compaction (true) or at the point in time at which they were visited (false)?

      kv_ep_compaction_expiry_fetch_inline     7.0.0 gauge

      If compaction requires a bgfetch before attempting expiry to ensure it does not expire an older version of the document, true: fetch it in the compaction thread. false: queue a bgfetch for the bgfetcher task to complete

      kv_ep_compaction_failed     7.1.0 gauge

      Counter of how many times compaction has failed, e.g. a system call error caused compaction to fail

      kv_ep_compaction_max_concurrent_ratio     7.0.0 gauge

      kv_ep_concurrent_pagers     7.0.0 gauge

      Number of eviction pager tasks to create when memory usage is high

      kv_ep_connection_manager_interval     7.0.0 gauge

      How often connection manager task should be run (in seconds).

      kv_ep_couchstore_file_cache_max_size     7.0.0 gauge

      Maximum number of couchstore files that we will keep open. Default value is 30 * 1024 (i.e. one file for each vBucket and 30 Buckets - the supported limit).

      kv_ep_couchstore_midpoint_rollback_optimisation     7.0.0 gauge

      Should we have to rollback more than half of the seqnos seen by this vBucket we will instead rollback to 0 and re-stream from the active if set to true

      kv_ep_couchstore_mprotect     7.0.0 gauge

      Enable couchstore to mprotect the iobuffer

      kv_ep_couchstore_tracing     7.0.0 gauge

      Enable couchstore tracing

      kv_ep_couchstore_write_validation     7.0.0 gauge

      Validate couchstore writes

      kv_ep_cross_bucket_ht_quota_sharing     7.0.0 gauge

      Allow this Bucket's HashTable quota to be shared with other Buckets which have this setting enabled.

      kv_ep_cursors_dropped     7.0.0 gauge

      Number of cursors dropped by the checkpoint remover

      kv_ep_data_read_failed     7.0.0 gauge

      Total number of get failures

      kv_ep_data_traffic_enabled     7.0.0 gauge

      True if we want to enable data traffic after warmup is complete

      kv_ep_data_write_failed     7.0.0 gauge

      Total compaction and commit failures

      kv_ep_db_data_size_bytes     7.0.0 gauge / bytes

      Total size of valid data in db files

      kv_ep_db_file_size_bytes     7.0.0 gauge / bytes

      Total size of the db files

      kv_ep_db_history_file_size_bytes     7.2.0 gauge / bytes

      The total size of all history currently stored by the bucket

      kv_ep_db_history_start_timestamp_seconds     7.2.0 gauge / seconds

      The timestamp of the oldest document stored in the history window, oldest of all vbuckets

      kv_ep_db_prepare_size_bytes     7.0.0 gauge / bytes

      Total size of SyncWrite prepares in db files

      kv_ep_dcp_backfill_byte_limit     7.0.0 gauge

      Max bytes a connection can backfill into memory before backfill is paused

      kv_ep_dcp_backfill_in_progress_per_connection_limit     7.0.0 gauge

      The maximum number of backfills each connection can have in-progress (i.e. KVStore snapshot open and reading data from)

      kv_ep_dcp_consumer_buffer_ratio     7.0.0 gauge

      Ratio of the BucketQuota that can be allocated by all DCP consumers for buffered messages

      kv_ep_dcp_consumer_control_enabled     7.0.0 gauge

      When true, a DcpConsumer can accept control messages. This is intended to be used by tests.

      kv_ep_dcp_consumer_flow_control_enabled     7.0.0 gauge

      Whether DCP Consumer on this node enable flow control

      kv_ep_dcp_consumer_process_buffered_messages_batch_size     7.0.0 gauge

      The maximum number of items stream->processBufferedMessages will consume.

      kv_ep_dcp_consumer_process_buffered_messages_yield_limit     7.0.0 gauge

      The number of processBufferedMessages iterations before forcing the task to yield.

      kv_ep_dcp_enable_noop     7.0.0 gauge

      Whether DCP Consumer connections should attempt to negotiate no-ops with the Producer

      kv_ep_dcp_idle_timeout     7.0.0 gauge

      The maximum number of seconds between dcp messages before a connection is disconnected

      kv_ep_dcp_min_compression_ratio     7.0.0 gauge

      kv_ep_dcp_noop_mandatory_for_v5_features     7.0.0 gauge

      Forces clients to enable noop for v5 features

      kv_ep_dcp_noop_tx_interval     7.0.0 gauge

      The time interval in seconds between noop messages being sent to the consumer

      kv_ep_dcp_oso_backfill_large_value_ratio     7.0.0 gauge

      kv_ep_dcp_oso_backfill_small_item_size_threshold     7.0.0 gauge

      kv_ep_dcp_oso_backfill_small_value_ratio     7.0.0 gauge

      kv_ep_dcp_oso_max_collections_per_backfill     7.0.0 gauge

      kv_ep_dcp_producer_snapshot_marker_yield_limit     7.0.0 gauge

      The number of snapshots before ActiveStreamCheckpointProcessorTask::run yields.

      kv_ep_dcp_scan_byte_limit     7.0.0 gauge

      Max bytes that can be read in a single backfill scan before yielding

      kv_ep_dcp_scan_item_limit     7.0.0 gauge

      Max items that can be read in a single backfill scan before yielding

      kv_ep_dcp_takeover_max_time     7.0.0 gauge

      Max amount of time for takeover send (in seconds) after which front end ops would return ETMPFAIL

      kv_ep_defragmenter_age_threshold     7.0.0 gauge

      How old (measured in number of DefragmenterVisitor passes) must a document be to be considered for defragmentation.

      kv_ep_defragmenter_auto_lower_threshold     7.0.0 gauge

      When mode is not static and scored fragmentation is above this value, a sleep time between defragmenter_auto_min_sleep and defragmenter_auto_max_sleep will be used

      kv_ep_defragmenter_auto_max_sleep     7.0.0 gauge

      The maximum sleep that the auto controller can set

      kv_ep_defragmenter_auto_min_sleep     7.0.0 gauge

      The minimum sleep that the auto controller can set

      kv_ep_defragmenter_auto_pid_d     7.0.0 gauge

      The d term for the PID controller

      kv_ep_defragmenter_auto_pid_dt     7.0.0 gauge

      The dt (interval) term for the PID controller. Value represents milliseconds

      kv_ep_defragmenter_auto_pid_i     7.0.0 gauge

      The i term for the PID controller

      kv_ep_defragmenter_auto_pid_p     7.0.0 gauge

      The p term for the PID controller

      kv_ep_defragmenter_auto_upper_threshold     7.0.0 gauge

      When mode is auto_linear and scored fragmentation is above this value, the defragmenter will use defragmenter_auto_min_sleep

      kv_ep_defragmenter_chunk_duration     7.0.0 gauge

      Maximum time (in ms) defragmentation task will run for before being paused (and resumed at the next defragmenter_interval).

      kv_ep_defragmenter_enabled     7.0.0 gauge

      True if defragmenter task is enabled

      kv_ep_defragmenter_interval     7.0.0 gauge

      How often defragmenter task should be run (in seconds).

      kv_ep_defragmenter_num_moved     7.0.0 gauge

      Number of items moved by the defragmentater task.

      kv_ep_defragmenter_num_visited     7.0.0 gauge

      Number of items visited (considered for defragmentation) by the defragmenter task.

      kv_ep_defragmenter_stored_value_age_threshold     7.0.0 gauge

      How old (measured in number of DefragmenterVisitor passes) must a StoredValue be to be considered for defragmentation.

      kv_ep_defragmenter_sv_num_moved     7.0.0 gauge

      Number of StoredValues moved by the defragmentater task.

      kv_ep_degraded_mode     7.0.0 gauge

      True if the engine is either warming up or data traffic is disabled

      kv_ep_diskqueue_drain     7.0.0 gauge

      Total drained items on disk queue

      kv_ep_diskqueue_fill     7.0.0 gauge

      Total enqueued items on disk queue

      kv_ep_diskqueue_items     7.0.0 gauge

      Total items in disk queue

      kv_ep_diskqueue_memory_bytes     7.0.0 gauge / bytes

      Total memory used in disk queue

      kv_ep_diskqueue_pending     7.0.0 gauge

      Total bytes of pending writes

      kv_ep_ephemeral_metadata_mark_stale_chunk_duration     7.0.0 gauge

      Maximum time (in ms) ephemeral hash table cleaner task will run for before being paused (and resumed at the next ephemeral_metadata_purge_interval).

      kv_ep_ephemeral_metadata_purge_age     7.0.0 gauge

      Age in seconds after which Ephemeral metadata is purged entirely from memory. Purging disabled if set to -1.

      kv_ep_ephemeral_metadata_purge_interval     7.0.0 gauge

      Time in seconds between automatic, periodic runs of the Ephemeral metadata purge task. Periodic purging disabled if set to 0.

      kv_ep_ephemeral_metadata_purge_stale_chunk_duration     7.0.0 gauge

      Maximum time (in ms) ephemeral stale metadata purge task will run for before being paused (and resumed at the next ephemeral_metadata_purge_interval).

      kv_ep_exp_pager_enabled     7.0.0 gauge

      True if expiry pager task is enabled

      kv_ep_exp_pager_initial_run_time     7.0.0 gauge

      Hour in GMT time when expiry pager can be scheduled for initial run

      kv_ep_exp_pager_stime     7.0.0 gauge

      Number of seconds between expiry pager runs.

      kv_ep_expired_access     7.0.0 gauge

      Number of times an item was expired on application access

      kv_ep_expired_compactor     7.0.0 gauge

      Number of times an item was expired by the compactor

      kv_ep_expired_pager     7.0.0 gauge

      Number of times an item was expired by the item pager

      kv_ep_expiry_pager_concurrency     7.0.0 gauge

      Number of tasks which are created to scan for and delete expired items

      kv_ep_expiry_pager_task_time     7.0.0 gauge

      Time of the next expiry pager task (GMT), NOT_SCHEDULED if expiry pager has been disabled

      kv_ep_failpartialwarmup     7.0.0 gauge

      If true then do not allow traffic to be enabled to the bucket if warmup didn't complete successfully

      kv_ep_flush_duration_total_seconds     7.0.0 gauge / seconds

      Cumulative milliseconds spent flushing

      kv_ep_flusher_todo     7.0.0 gauge

      Number of items currently being written

      kv_ep_flusher_total_batch_limit     7.0.0 gauge

      Number of items that all flushers can be currently flushing. Each flusher has flusher_total_batch_limit / num_writer_threads individual batch size. Individual batches may be larger than this value, as we cannot split Memory checkpoints across multiple commits.

      kv_ep_freq_counter_increment_factor     7.0.0 gauge

      The increment factor of the ProbabilisticCounter being used for the frequency counter. The default value of 0.012 is set such that it allows an 8-bit ProbabilisticCounter to mimic a uint16 counter. See the comment on the ProbabilisticCounter class for more information.

      kv_ep_fsync_after_every_n_bytes_written     7.0.0 gauge

      Perform a file sync() operation after every N bytes written. Disabled if set to 0.

      kv_ep_getl_default_timeout     7.0.0 gauge

      The default timeout for a getl lock in (s)

      kv_ep_getl_max_timeout     7.0.0 gauge

      The maximum timeout for a getl lock in (s)

      kv_ep_history_retention_bytes     7.0.0 gauge

      Max bytes of history a bucket should aim to retain on disk.

      kv_ep_history_retention_seconds     7.0.0 gauge

      Seconds of history the bucket should aim to retain on disk.

      kv_ep_hlc_drift_ahead_threshold_us     7.0.0 gauge

      The μs threshold of drift at which we will increment a vbucket's ahead counter.

      kv_ep_hlc_drift_behind_threshold_us     7.0.0 gauge

      The μs threshold of drift at which we will increment a vbucket's behind counter.

      kv_ep_hlc_drift_count     7.0.0 gauge

      The accumulated number of times the corresponding kv_ep_hlc_drift_count has been updated

      kv_ep_hlc_drift_seconds     7.0.0 gauge / seconds

      The accumulated drift between this node's HLC and the remote node. For active vbucket's this represents the difference in CAS and local HLC for withMeta operations, for replica vbucket's this represents the difference in CAS and local HLC from DCP replication.

      kv_ep_ht_item_memory_bytes     7.1.0 gauge / bytes

      The total byte size of all items, no matter the vbucket's state, no matter if an item's value is ejected. Tracks the same value as ep_total_cache_size

      kv_ep_ht_locks     7.0.0 gauge

      kv_ep_ht_resize_interval     7.0.0 gauge

      Interval in seconds to wait between HashtableResizerTask executions.

      kv_ep_ht_size     7.0.0 gauge

      Initial number of slots in HashTable objects.

      kv_ep_io_bg_fetch_read_count     7.0.0 gauge

      Accumulated count of read system calls issued by BG fetches, only maintained by couchstore buckets

      kv_ep_io_compaction_read_bytes_bytes     7.0.0 gauge / bytes

      Total number of bytes read during compaction

      kv_ep_io_compaction_write_bytes_bytes     7.0.0 gauge / bytes

      Total number of bytes written during compaction

      kv_ep_io_document_write_bytes_bytes     7.0.0 gauge / bytes

      Total number of bytes written. Only maintained by couchstore buckets and includes Couchstore B-Tree and other overheads

      kv_ep_io_total_read_bytes_bytes     7.0.0 gauge / bytes

      Total number of bytes read

      kv_ep_io_total_write_bytes_bytes     7.0.0 gauge / bytes

      Total number of bytes written

      kv_ep_item_begin_failed     7.0.0 gauge

      Number of times a transaction failed to start due to storage errors

      kv_ep_item_commit_failed     7.0.0 gauge

      Number of times a transaction failed to commit due to storage errors

      kv_ep_item_compressor_chunk_duration     7.0.0 gauge

      Maximum time (in ms) item compression task will run for before being paused (and resumed at the next item_compressor_interval).

      kv_ep_item_compressor_interval     7.0.0 gauge

      How often the item compressor task should run (in milliseconds)

      kv_ep_item_compressor_num_compressed     7.0.0 gauge

      Number of items compressed by the item compressor task.

      kv_ep_item_compressor_num_visited     7.0.0 gauge

      Number of items visited (considered for compression) by the item compressor task.

      kv_ep_item_eviction_age_percentage     7.0.0 gauge

      The age percentage used when determining the age threshold in the learning_age_and_mfu eviction policy.

      kv_ep_item_eviction_freq_counter_age_threshold     7.0.0 gauge

      kv_ep_item_eviction_initial_mfu_percentile     7.0.0 gauge

      Percentile of existing item MFU distribution to use to determine the MFU to give to new items (0 would insert new items with MFU equal to that of the coldest item present; 100 to that of hottest item present) for the upfront_mfu_only eviction strategy.

      kv_ep_item_eviction_initial_mfu_update_interval     7.0.0 gauge

      Time between updates of the initial MFU given to new items (seconds)

      kv_ep_item_flush_expired     7.0.0 gauge

      Number of times an item is not flushed due to the expiry of the item

      kv_ep_item_flush_failed     7.0.0 gauge

      Number of times an item failed to flush due to storage errors

      kv_ep_item_freq_decayer_chunk_duration     7.0.0 gauge

      Maximum time (in ms) itemFreqDecayer task will run for before being paused.

      kv_ep_item_freq_decayer_percent     7.0.0 gauge

      The percent that the frequency counter of a document is decayed when visited by item_freq_decayer.

      kv_ep_item_num     7.0.0 gauge

      The number of item objects allocated

      kv_ep_items_expelled_from_checkpoints     7.0.0 gauge

      Number of items expelled from checkpoints. Expelled refers to items that have been ejected from memory but are still considered to be part of the checkpoint.

      kv_ep_items_rm_from_checkpoints     7.0.0 gauge

      Number of items removed from closed unreferenced checkpoints

      kv_ep_key_value_size_bytes     7.0.0 gauge / bytes

      Memory used to store items metadata, keys and values in the system, no matter the vbucket's state

      kv_ep_magma_active_disk_usage_bytes     7.2.0 gauge / bytes

      Compressed disk size of latest version of the LSM Trees. This includes history

      kv_ep_magma_block_cache_hits     7.1.0 gauge

      Number of block cache hits

      kv_ep_magma_block_cache_mem_used_bytes     7.1.0 gauge / bytes

      Memory used by block cache. Accounts for allocated size of blocks that includes allocator internal fragmentation and any internal cache overheads due to auxilliary structures

      kv_ep_magma_block_cache_misses     7.1.0 gauge

      Number of block cache misses

      kv_ep_magma_bloom_filter_accuracy     7.0.0 gauge

      kv_ep_magma_bloom_filter_accuracy_for_bottom_level     7.0.0 gauge

      kv_ep_magma_bloom_filter_mem_used_bytes     7.1.0 gauge / bytes

      Bloom filter memory usage in all versions of the LSM Trees

      kv_ep_magma_buffer_mem_used_bytes     7.1.0 gauge / bytes

      Memory usage for some buffers

      kv_ep_magma_bytes_incoming_bytes     7.1.0 gauge / bytes

      Data written to key, seq, local index as part of the KV frontend writes.

      kv_ep_magma_bytes_outgoing_bytes     7.1.0 gauge / bytes

      Total bytes returned via get (excluding bytes returned from sequence iterator)

      kv_ep_magma_bytes_per_read_ratio     7.1.0 gauge / ratio

      Bytes read by get / number of Gets

      kv_ep_magma_checkpoint_disk_usage_bytes     7.2.0 gauge / bytes

      Checkpoint overhead

      kv_ep_magma_checkpoint_interval     7.0.0 gauge

      Frequency of checkpoint interval; in seconds. A checkpoint provides a rollback point to which the data store can rollback to in the event of a failure.

      kv_ep_magma_checkpoint_threshold     7.0.0 gauge

      Threshold of data written before a checkpoint is created; threshold is based on a fraction of the total data size. Checkpoints require data to be retained in order to provide rollback capability. If the amount of data written during a checkpoint interval is large, we need to do more frequent checkpoints to reduce space amplification.

      kv_ep_magma_compactions     7.1.0 gauge

      Count of Magma compactions in key, seq and local index.

      kv_ep_magma_data_blocks_compressed_size     7.2.0 gauge

      Data blocks compressed size; actual size in storage

      kv_ep_magma_data_blocks_compression_ratio_ratio     7.2.0 gauge / ratio

      The compression ratio calculated by dividing the uncompressed data size by the compressed data size

      kv_ep_magma_data_blocks_space_reduction_estimate_pct_ratio     7.2.0 gauge / ratio

      Estimated percentage of space savings in compressed data blocks (0-100)

      kv_ep_magma_data_blocks_uncompressed_size     7.2.0 gauge

      Data blocks uncompressed size

      kv_ep_magma_delete_frag_ratio     7.0.0 gauge

      Magma compaction always removes duplicate keys but not all sstables are visited during compaction.. This is the minimum fragmentation ratio threshold for when a compaction will be triggerred.

      kv_ep_magma_delete_memtable_writecache     7.0.0 gauge

      Magma uses a lazy update model to maintain the sequence index. It maintains a list of deleted seq #s that were deleted from the key Index.

      kv_ep_magma_enable_block_cache     7.0.0 gauge

      The block cache is an LRU policy driven cache that is used to maintain index blocks for the sstable's btrees.

      kv_ep_magma_enable_direct_io     7.0.0 gauge

      Using direct IO tells magma to bypass the file system cache when writing or reading sstables.

      kv_ep_magma_enable_group_commit     7.0.0 gauge

      kv_ep_magma_enable_memory_optimized_writes     7.0.0 gauge

      When enabled, if copying a write batch into memtable results in exceeding the write cache quota, Magma avoids the copy and instead flushes the batch to disk on the writer thread itself. This tradeoffs an increase in write latency for reduced memory consumption and obeys quota limits. If copying a batch keeps us under the quota, Magma will to continue to copy and do the flush in background.

      kv_ep_magma_enable_upsert     7.0.0 gauge

      When true, the kv_engine will utilize Magma's upsert capabiltiy but accurate document counts for the data store or collections can not be maintained.

      kv_ep_magma_enable_wal     7.0.0 gauge

      WAL ensures Magma's atomicity, durability. Disabling it is useful in performance analysis.

      kv_ep_magma_expiry_frag_threshold     7.0.0 gauge

      All compactions perform expiry but not all sstables are visited by compaction. Magma maintains an expiry histogram across the kvstore to help determine which range of sstables need to have compaction run on them because there are a significant number of expired items. The frag threshold is the number of expired keys vs keys in the data store.

      kv_ep_magma_expiry_purger_interval     7.0.0 gauge

      Magma maintains statistics about expired documents to run compaction based on magma_expiry_frag_threshold. This config determines the the expiry purger polling interval in seconds to trigger compaction on eligible sstables

      kv_ep_magma_filecount_compactions     7.1.0 gauge

      Number of compactions triggered by file count

      kv_ep_magma_flusher_thread_percentage     7.0.0 gauge

      Percentage of storage threads that are flusher threads (i.e. with a value of 20 we will allocate 4 (1/5th) of the storage threads to flushers and the remaining 16 (4/5ths) threads will be compactors).

      kv_ep_magma_flushes     7.1.0 gauge

      Number of write cache flushes performed

      kv_ep_magma_fragmentation_percentage     7.0.0 gauge

      The percentage of fragmentation a magma bucket aims to maintain. A 100 value will disable sequence tree compactions by setting the desired fragmentation percentage to 100%. Smaller compactions of the key and local indexes will still run.

      kv_ep_magma_fragmentation_ratio     7.1.0 gauge / ratio

      Fragmentation on disk (excludes history)

      kv_ep_magma_gets     7.1.0 gauge

      Number of get operations

      kv_ep_magma_group_commit_max_sync_wait_duration_ms     7.0.0 gauge

      kv_ep_magma_group_commit_max_transaction_count     7.0.0 gauge

      kv_ep_magma_heartbeat_interval     7.0.0 gauge

      Frequency of heartbeat interval; in seconds. A heartbeat task is scheduled to provide cleanup and maintenance when magma is idle.

      kv_ep_magma_histogram_mem_used_bytes     7.1.0 gauge / bytes

      Memory usage for MagmaHistogramStats and file histograms

      kv_ep_magma_history_logical_data_size_bytes     7.2.0 gauge / bytes

      The logical data size of history

      kv_ep_magma_history_logical_disk_size_bytes     7.2.0 gauge / bytes

      The logical disk size of history

      kv_ep_magma_history_size_evicted_bytes     7.2.0 gauge / bytes

      History eviction bytes based on size

      kv_ep_magma_history_time_evicted_bytes     7.2.0 gauge / bytes

      History eviction bytes based on time

      kv_ep_magma_index_resident_ratio_ratio     7.1.0 gauge / ratio

      Proportion of keyIndex (data+index blocks) and seqIndex (index blocks) in memory

      kv_ep_magma_initial_wal_buffer_size     7.0.0 gauge

      The WAL buffer is used to stage items to the write ahead log along with control information like begin and end transaction. This parameter refers to the initial WAL buffer size. The WAL buffer will adjust its size up to a maximum of 4MB or down to a minimum of 64KB depending on the transaction batch size with consideration for other magma components which consume memory such as the block cache, bloom filters, write cache and meta data overhead.

      kv_ep_magma_inserts     7.1.0 gauge

      Number of DocInsert operations

      kv_ep_magma_key_tree_data_block_size     7.0.0 gauge

      Magma uses SSTables for storage. SSTables are made up of different types of blocks. Data blocks contain the bulk of the data and contain the key and metadata for each of the items in the block. Larger block sizes can decrease storage space by better block compression but they require more memory, cpu and io bandwidth to read and write them.

      kv_ep_magma_key_tree_index_block_size     7.0.0 gauge

      Magma uses SSTables for storage. SSTables are made up of different types of blocks. Index blocks contain keys that help traverse the SSTable to locate the data item. Larger block sizes can decrease storage space by better block compression but they require more memory, cpu and io bandwidth to read and write them.

      kv_ep_magma_keyindex_filecount_compactions     7.2.0 gauge

      Number of compactions triggered by file count for the KeyIndex

      kv_ep_magma_keyindex_writer_compactions     7.2.0 gauge

      Number of compaction performed on the writer thread for the KeyIndex

      kv_ep_magma_logical_data_size_bytes     7.1.0 gauge / bytes

      The logical data size, including history

      kv_ep_magma_logical_disk_size_bytes     7.1.0 gauge / bytes

      The logical disk size, including history

      kv_ep_magma_lsmtree_object_mem_used_bytes     7.1.0 gauge / bytes

      Memory used by LSMTree objects

      kv_ep_magma_max_checkpoints     7.0.0 gauge

      Maximum # of checkpoints retained for rollback.

      kv_ep_magma_max_default_storage_threads     7.0.0 gauge

      If the number of storage threads = 0, then we set the number of storage threads based on the number of writer threads up to a maximum of 20 threads and use magma_flusher_thread_percentage to determine the ratio of flusher and compactor threads.

      kv_ep_magma_max_level_0_ttl     7.0.0 gauge

      Maximum time (in seconds) that data is kept in level 0 before it is merged.

      kv_ep_magma_max_recovery_bytes     7.0.0 gauge

      Maximum amount of data that is replayed from the WAL during magma recovery. When this threshold is reached magma, creates a temporary checkpoint to recover at. This is per kvstore and in bytes.

      kv_ep_magma_max_write_cache     7.0.0 gauge

      Magma uses a common skiplist to buffer all items at the shard level called the write cache. The write cache contains items from all the kvstores that are part of the shard and when it is flushed, each kvstore will receive a few items each. Regardless of how much memory might be available, this would be the maximum amount that could be allocated.

      kv_ep_magma_mem_quota_low_watermark_ratio     7.0.0 gauge

      Fraction of memory quota used by magma as it's low water mark. Magma uses this low watermark to size it's write cache and block cache. This sizing includes bloom filters memory usage but bloom filter eviction is based on the memory quota

      kv_ep_magma_mem_quota_ratio     7.0.0 gauge

      Magma total memory ratio of the Bucket Quota across all shards and Magma limit's it's memory usage to this value.

      kv_ep_magma_min_checkpoint_interval     7.0.0 gauge

      Minimum interval between two checkpoints; in seconds. Prevents excessive creation of checkpoints.

      kv_ep_magma_min_value_block_size_threshold     7.0.0 gauge

      Magma creates value blocks for values larger than this size. Value blocks only contain a single KV item and their reads/writes are optimised for memory as it avoids many value copies. Right now compression is turned off for value blocks to reduce memory consumption while building them. This setting should be at least as large as the SeqIndex block size.

      kv_ep_magma_per_document_compression_enabled     7.0.0 gauge

      Apply Snappy compression to each document when persisted (magma only)

      kv_ep_magma_read_ahead_buffer_mem_used_bytes     7.1.0 gauge / bytes

      Memory consumed by read ahead buffers. They are used for compactions and sequence iterators. This is included in BufferMemUsed

      kv_ep_magma_read_bytes_bytes     7.1.0 gauge / bytes

      Total bytes read from disk as per Magma's manual accounting in various code paths

      kv_ep_magma_read_bytes_compact_bytes     7.1.0 gauge / bytes

      Total bytes read from disk by compactors

      kv_ep_magma_read_bytes_get_bytes     7.1.0 gauge / bytes

      Total bytes read from disk by gets

      kv_ep_magma_readamp_get_ratio     7.1.0 gauge / ratio

      Bytes Read from disk by only Get threads / Bytes outgoing

      kv_ep_magma_readamp_ratio     7.1.0 gauge / ratio

      Bytes read from disk / bytes outgoing. Bytes read from disk includes Gets and compactors (excluding WAL)

      kv_ep_magma_readio     7.1.0 gauge

      Number of read IOs performed

      kv_ep_magma_readioamp_ratio     7.1.0 gauge / ratio

      Number of read IOs performed by GetDocs divided by the number of GetDocs

      kv_ep_magma_seq_tree_data_block_size     7.0.0 gauge

      Magma uses SSTables for storage. SSTables are made up of different types of blocks. Data blocks contain the bulk of the data and contain the key, metadata and value for each of the items in the block. Larger block sizes can decrease storage space by better block compression but they require more memory, cpu and io bandwidth to read and write them.

      kv_ep_magma_seq_tree_index_block_size     7.0.0 gauge

      Magma uses SSTables for storage. SSTables are made up of different types of blocks. Index blocks contain keys that help traverse the SSTable to locate the data item. Larger block sizes can decrease storage space by better block compression but they require more memory, cpu and io bandwidth to read and write them.

      kv_ep_magma_seqindex_filecount_compactions     7.2.0 gauge

      Number of compactions triggered by file count for the SeqIndex

      kv_ep_magma_seqindex_writer_compactions     7.2.0 gauge

      Number of compaction performed on the writer thread for the SeqIndex

      kv_ep_magma_sets     7.1.0 gauge

      Number of set operations (DocUpsert)

      kv_ep_magma_sync_every_batch     7.0.0 gauge

      Couchstore generates a commit point at the end of every batch of items. During normal operation, Magma checkpoints are taken at every magma_checkpoint_interval. Many of the tests require more frequent checkpoints so this configuration parameter makes sure every batch generates a checkpoint. Each checkpoint generated in this way is a "Sync" checkpoint and isn't going to be useful for rollback as it only the latest checkpoint is a "Sync" checkpoiont. A "Rollback" checkpoint will be made instead if we set magma_checkpoint_interval to 0. The "Rollback" checkpoints are stored in the checkpoint queue as potential rollback points. Should be used for testing only!

      kv_ep_magma_syncs     7.1.0 gauge

      Number of fsyncs performed

      kv_ep_magma_table_meta_mem_used_bytes     7.1.0 gauge / bytes

      Memory used by sstable metadata

      kv_ep_magma_table_object_mem_used_bytes     7.1.0 gauge / bytes

      Memory used by SSTable objects

      kv_ep_magma_tables     7.1.0 gauge

      Number of files used for tables

      kv_ep_magma_tables_created     7.1.0 gauge

      Number of table files created

      kv_ep_magma_tables_deleted     7.1.0 gauge

      Number of table files deleted

      kv_ep_magma_total_disk_usage_bytes     7.1.0 gauge / bytes

      Compressed size of all SSTables in all checkpoints, WAL and any other files on disk

      kv_ep_magma_total_mem_used_bytes     7.1.0 gauge / bytes

      Total memory used by bloom filters, write cache, block cache and index blocks This account for all versions of the trees

      kv_ep_magma_ttl_compactions     7.1.0 gauge

      Number of time-to-live based compactions

      kv_ep_magma_wal_disk_usage_bytes     7.1.0 gauge / bytes

      Disk usage by the WAL

      kv_ep_magma_wal_mem_used_bytes     7.1.0 gauge / bytes

      Total WAL memory used, including WAL buffer and any auxiliary memory

      kv_ep_magma_write_bytes_bytes     7.1.0 gauge / bytes

      Bytes written by Magma flushes, compactions and WAL writes.

      kv_ep_magma_write_bytes_compact_bytes     7.1.0 gauge / bytes

      Bytes written by Magma compactions.

      kv_ep_magma_write_cache_mem_used_bytes     7.1.0 gauge / bytes

      Memory usage of the write cache

      kv_ep_magma_write_cache_ratio     7.0.0 gauge

      Memory is maintained across 3 magma components; Bloom filters, Block cache and Write cache. The least important of these is the write cache. If there is insufficent memory for the write cache, the write cache will grow to the size of the batch and then be immediately flushed and freed. If there is available memory, the write cache is limited to 20% of the available memory (after bloom filter and block cache get their memory up to magma_max_write_cache (128MB). Bloom filters are the most important and are never paged out. Bloom filter memory can cause magma to go above the memory quota. To allevaite this, the bottom layer where the majority of bloom filter memory is, won't use bloom filters when OptimizeBloomFilterForMisses is on (which it is by default). The block cache grows each time the index sizes change. But its growth is bounded by the available memory or what's left over after the bloom filter memory is subtracted.

      kv_ep_magma_writer_compactions     7.1.0 gauge

      Number of compaction performed on the writer thread

      kv_ep_max_checkpoints     7.0.0 gauge

      The expected max number of checkpoints in each VBucket on a balanced system. Note: That is not a hard limit on the single vbucket. That is used (together with checkpoint_memory_ratio) for computing checkpoint_max_size, which triggers checkpoint creation.

      kv_ep_max_failover_entries     7.0.0 gauge

      maximum number of failover log entries

      kv_ep_max_item_privileged_bytes     7.0.0 gauge

      Maximum number of bytes allowed for 'privileged' (system) data for an item in addition to the max_item_size bytes

      kv_ep_max_item_size     7.0.0 gauge

      Maximum number of bytes allowed for an item

      kv_ep_max_num_bgfetchers     7.0.0 gauge

      Maximum number of bg fetcher objects (the number of concurrent bg fetch tasks we can run). 0 = auto-configure which means we use the same number as the number of shards (max_num_shards - for historic reasons). See also num_reader_threads.

      kv_ep_max_num_flushers     7.0.0 gauge

      Maximum number of flusher objects (the number of concurrent flusher tasks we can run). 0 = auto-configure which means we use the same number as the number of shards (max_num_shards - for historic reasons). See also num_writer_threads.

      kv_ep_max_num_shards     7.0.0 gauge

      Maximum mumber of shards (0 = auto-configure)

      kv_ep_max_num_workers     7.0.0 gauge

      Bucket Priority relative to other buckets

      kv_ep_max_size     7.0.0 gauge

      Memory quota (in bytes) for this bucket.

      kv_ep_max_threads     7.0.0 gauge

      Maximum number of threads of any single class (0 = automatically select based on core count)

      kv_ep_max_ttl     7.0.0 gauge

      A maximum TTL (in seconds) that will apply to all new documents, documents set with no TTL will be given this value. A value of 0 means this is disabled

      kv_ep_max_vbuckets     7.0.0 gauge

      Maximum number of vbuckets expected

      kv_ep_mem_freed_by_checkpoint_item_expel_bytes     7.1.0 gauge / bytes

      Memory recovered from Checkpoint by expelling clean items (i.e. items processed by all cursors) from the queue

      kv_ep_mem_freed_by_checkpoint_removal_bytes     7.1.0 gauge / bytes

      Amount of memory freed through ckpt removal

      kv_ep_mem_high_wat     7.0.0 gauge

      kv_ep_mem_high_wat_percent_ratio     7.0.0 gauge / ratio

      High water mark (as a percentage)

      kv_ep_mem_low_wat     7.0.0 gauge

      kv_ep_mem_low_wat_percent_ratio     7.0.0 gauge / ratio

      Low water mark (as a percentage)

      kv_ep_mem_tracker_enabled     7.0.0 gauge

      True if memory usage tracker is enabled

      kv_ep_mem_used_merge_threshold_percent     7.0.0 gauge

      What percent of max_data size should we allow the estimated total memory to lag by (EPStats::getEstimatedTotalMemoryUsed)

      kv_ep_meta_data_disk_bytes     7.0.0 gauge / bytes

      Estimate of how much metadata has been written to disk since startup

      kv_ep_meta_data_memory_bytes     7.0.0 gauge / bytes

      Total memory used by meta data, including the key

      kv_ep_min_compression_ratio     7.0.0 gauge

      specifies a minimum compression ratio below which storing the document will be stored as uncompressed.

      kv_ep_mutation_mem_ratio     7.0.0 gauge

      kv_ep_num_access_scanner_runs     7.0.0 gauge

      Number of times we ran accesss scanner to snapshot working set

      kv_ep_num_access_scanner_skips     7.0.0 gauge

      Number of times accesss scanner task decided not to generate access log

      kv_ep_num_checkpoints     7.1.0 gauge

      The number of checkpoint objects allocated

      kv_ep_num_eject_failures     7.0.0 gauge

      Number of items that could not be ejected

      kv_ep_num_expiry_pager_runs     7.0.0 gauge

      Number of times we ran expiry pager loops to purge expired items from memory/disk

      kv_ep_num_freq_decayer_runs     7.0.0 gauge

      Number of times we ran the freq decayer task because a frequency counter has become saturated

      kv_ep_num_non_resident     7.0.0 gauge

      The number of non-resident items

      kv_ep_num_not_my_vbuckets     7.0.0 gauge

      Number of times Not My VBucket exception happened during runtime

      kv_ep_num_pager_runs     7.0.0 gauge

      Number of times we ran pager loops to seek additional memory

      kv_ep_num_value_ejects     7.0.0 gauge

      Number of times item values got ejected from memory to disk

      kv_ep_num_workers     7.0.0 gauge

      Global number of shared worker threads

      kv_ep_oom_errors     7.0.0 gauge

      Number of times unrecoverable OOMs happened while processing operations

      kv_ep_pager_sleep_time_ms     7.0.0 gauge

      How long in milliseconds the ItemPager will sleep for when not being requested to run

      kv_ep_pending_compactions     7.0.0 gauge

      Number of pending vbucket compactions

      kv_ep_pending_ops     7.0.0 gauge

      Number of ops awaiting pending vbuckets

      kv_ep_pending_ops_max     7.0.0 gauge

      Max ops seen awaiting 1 pending vbucket

      kv_ep_pending_ops_max_duration_seconds     7.0.0 gauge / seconds

      Max time (µs) used waiting on pending vbuckets

      kv_ep_pending_ops_total     7.0.0 gauge

      Total blocked pending ops since reset

      kv_ep_persist_vbstate_total     7.0.0 gauge

      Total VB persist state to disk

      kv_ep_persistent_metadata_purge_age     7.0.0 gauge

      Age in seconds after which tombstones may be purged. Defaults to 3 days. Max of 60 days. If this is dynamically changed for a magma bucket then magma may not trigger compactions when it should, this can be avoided by running a full manual compaction after changing this parameter.

      kv_ep_pitr_enabled     7.0.0 gauge

      Is PiTR enabled or not

      kv_ep_pitr_granularity     7.0.0 gauge

      The granularity (interval between each rollback point) in seconds (up to 5 hours)

      kv_ep_pitr_max_history_age     7.0.0 gauge

      The number of seconds of the oldest entry to keep as part of compaction (up to 48 hours)

      kv_ep_queue_size     7.0.0 gauge

      Number of items queued for storage

      kv_ep_range_scan_kv_store_scan_ratio     7.0.0 gauge

      The ratio for calculating how many RangeScans can exist, a ratio of total KVStore scans.

      kv_ep_range_scan_max_continue_tasks     7.0.0 gauge

      The maximum number of range scan tasks that can exist concurrently. Setting to 0 results in num_auxio_threads - 1 tasks

      kv_ep_range_scan_max_lifetime     7.0.0 gauge

      The maximum lifetime in seconds for a range-scan. Scans that don't complete before this limit are cancelled

      kv_ep_range_scan_read_buffer_send_size     7.0.0 gauge

      The size of a buffer used to store data read during the I/O phase of a range-scan-continue. Once the buffer size is >= to this value the data is sent to the connection

      kv_ep_retain_erroneous_tombstones     7.0.0 gauge

      whether erroneous tombstones need to be retain during compaction. Erroneous tombstones are those that have invalid meta data in it. For example, a delete time of 0.

      kv_ep_rollback_count     7.0.0 gauge

      Number of rollbacks on consumer

      kv_ep_seqno_persistence_timeout     7.0.0 gauge

      Timeout in seconds after which a pending SeqnoPersistence operation is temp-failed

      kv_ep_startup_time_seconds     7.0.0 gauge / seconds

      System-generated engine startup time

      kv_ep_storedval_num     7.0.0 gauge

      The number of storedval objects allocated

      kv_ep_sync_writes_max_allowed_replicas     7.0.0 gauge

      The maximum number of supported replicas for SyncWrites. Attempts to issue SyncWrites against a topology with more replicas than this setting will fail with DurabilityImpossible.

      kv_ep_tmp_oom_errors     7.0.0 gauge

      Number of times temporary OOMs happened while processing operations

      kv_ep_total_cache_size_bytes     7.0.0 gauge / bytes

      The total byte size of all items, no matter the vbucket's state, no matter if an item's value is ejected. Tracks the same value as ep_ht_item_memory

      kv_ep_total_deduplicated     7.0.0 gauge

      Total number of items de-duplicated when queued to CheckpointManager

      kv_ep_total_deduplicated_flusher     7.2.0 gauge

      Total number of items de-duplicated when flushed to disk

      kv_ep_total_del_items     7.0.0 gauge

      Total number of persisted deletions

      kv_ep_total_enqueued     7.0.0 gauge

      Total number of items queued for persistence

      kv_ep_total_new_items     7.0.0 gauge

      Total number of persisted new items

      kv_ep_total_persisted     7.0.0 gauge

      Total number of items persisted

      kv_ep_uncommitted_items     7.0.0 gauge

      The amount of items that have not been written to disk

      kv_ep_vb_total     7.0.0 gauge

      Total vBuckets (count)

      kv_ep_vbucket_del     7.0.0 gauge

      Number of vbucket deletion events

      kv_ep_vbucket_del_avg_walltime_seconds     7.0.0 gauge / seconds

      Avg wall time (µs) spent by deleting a vbucket

      kv_ep_vbucket_del_fail     7.0.0 gauge

      Number of failed vbucket deletion events

      kv_ep_vbucket_del_max_walltime_seconds     7.0.0 gauge / seconds

      Max wall time (µs) spent by deleting a vbucket

      kv_ep_vbucket_mapping_sanity_checking     7.0.0 gauge

      Are vBucket mappings (key -> vBucket) checked by the server? This is a sanity checking mode which crc32 hashes the key to ensure that the client is supplying the expected vBucket for each key.

      kv_ep_warmup     7.0.0 gauge

      Is Warmup of existing data enabled

      kv_ep_warmup_access_log     7.1.0 gauge

      Number of keys present in access log

      kv_ep_warmup_backfill_scan_chunk_duration     7.0.0 gauge

      The duration (in ms) after which warmup's backfill scans will yield and re-schedule; allowing other tasks on the same threads to run.

      kv_ep_warmup_batch_size     7.0.0 gauge

      The size of each batch loaded during warmup.

      kv_ep_warmup_dups     7.0.0 gauge

      Duplicates encountered during warmup

      kv_ep_warmup_estimate_time_seconds     7.1.0 gauge / seconds

      Total time spent in the estimate item count phase of warmup

      kv_ep_warmup_estimated_key_count     7.1.0 gauge

      Estimated number of keys in database

      kv_ep_warmup_estimated_value_count     7.1.0 gauge

      Estimated number of values in database

      kv_ep_warmup_key_count     7.1.0 gauge

      Number of keys warmed up

      kv_ep_warmup_keys_time_seconds     7.1.0 gauge / seconds

      Time (µs) spent by warming keys

      kv_ep_warmup_min_item_threshold     7.1.0 gauge

      The minimum number of items that needs to be warmed up before external data mutations is allowed. This is in % of the number of items.

      kv_ep_warmup_min_items_threshold     7.0.0 gauge

      Percentage of total items warmed up before we enable traffic.

      kv_ep_warmup_min_memory_threshold     7.0.0 gauge

      Percentage of max mem warmed up before we enable traffic.

      kv_ep_warmup_oom     7.0.0 gauge

      OOMs encountered during warmup

      kv_ep_warmup_status     7.2.0 gauge

      The current status of the warmup thread

      kv_ep_warmup_thread     7.0.0 gauge

      Warmup thread status

      kv_ep_warmup_time_seconds     7.0.0 gauge / seconds

      Time (µs) spent by warming data

      kv_ep_warmup_value_count     7.1.0 gauge

      Number of values warmed up

      kv_ep_xattr_enabled     7.0.0 gauge

      kv_item_alloc_sizes_bytes     7.0.0 histogram / bytes

      Item allocation size counters (in bytes)

      kv_lock_errors     7.0.0 gauge

      The number of times an operation failed due to accessing a locked document

      kv_magma_compactions     7.2.0 gauge

      Count of Magma compactions

      kv_mem_used_bytes     7.0.0 gauge / bytes

      Engine's total memory usage

      kv_mem_used_estimate_bytes     7.0.0 gauge / bytes

      Engine's total estimated memory usage (this is a faster stat to read, but lags mem_used as it's only updated when a threshold is crossed see mem_used_merge_threshold)

      kv_memcache_curr_items     7.0.0 gauge

      Number of active items in memory

      kv_memcache_engine_maxbytes     7.0.0 gauge

      The max size of the bucket

      kv_memcache_evictions     7.0.0 gauge

      Number of items evicted from the bucket

      kv_memcache_mem_size_bytes     7.0.0 gauge / bytes

      Engine's total memory usage

      kv_memcache_reclaimed     7.0.0 gauge

      Number of items allocated by reusing expired objects

      kv_memcache_total_items     7.0.0 gauge

      Total number of items in the bucket

      kv_memory_overhead_bytes     7.0.0 gauge / bytes

      The "unused" memory caused by the allocator returning bigger chunks than requested

      kv_memory_used_bytes     7.0.0 gauge / bytes

      Memory used for various objects

      kv_num_high_pri_requests     7.0.0 gauge

      Num of async high priority requests

      kv_num_vbuckets     7.0.0 gauge

      Number of vBuckets

      kv_ops     7.0.0 gauge

      Number of operations

      kv_ops_failed     7.0.0 gauge

      Number of operations failed due to conflict resolution

      kv_read_bytes     7.0.0 gauge / bytes

      The number bytes received from all connections bound to this bucket

      kv_rejected_conns     7.0.0 gauge

      The number of connections rejected due to hitting the maximum number of connections

      kv_rollback_item_count     7.0.0 gauge

      Num of items rolled back

      kv_scope_collection_count     7.0.0 gauge

      Number of collections in the scope

      kv_stat_reset     7.0.0 gauge

      Timestamp when the stats was reset

      kv_stat_timings_mem_usage_bytes     7.1.0 gauge / bytes

      The memory footprint for tracing times spent processing stat requests

      kv_subdoc_lookup_extracted_bytes     7.0.0 gauge / bytes

      The total number of bytes from the documents being returned as part of subdoc lookup operations

      kv_subdoc_lookup_searched_bytes     7.0.0 gauge / bytes

      The total size of all documents used for subdoc lookup operations

      kv_subdoc_mutation_inserted_bytes     7.0.0 gauge / bytes

      The total number of bytes inserted into the documents via subdoc

      kv_subdoc_mutation_updated_bytes     7.0.0 gauge / bytes

      The total number of bytes for the documents mutated via subdoc

      kv_subdoc_ops     7.0.0 gauge

      The number of subdoc operations

      kv_sync_write_commit_duration_seconds     7.0.0 histogram / seconds

      Commit duration for SyncWrites

      kv_system_connections     7.0.0 gauge

      The number of connections to system ports in memcached

      kv_threads     7.0.0 gauge

      The number of threads used to serve clients

      kv_time_seconds     7.0.0 gauge / seconds

      The servers current time (seconds since January 1st, 1970 at 00:00:00 UTC)

      kv_total_connections     7.0.0 gauge

      The total number of connections to this system since the process started (or reset)

      kv_total_memory_overhead_bytes     7.0.0 gauge / bytes

      Extra memory used by transient data like persistence queue, replication queues, checkpoints, etc

      kv_total_memory_used_bytes     7.0.0 gauge / bytes

      Engine's total memory usage

      kv_total_resp_errors     7.0.0 gauge

      The number of error messages returned

      kv_uptime_seconds     7.0.0 gauge / seconds

      The number of seconds elapsed since process start

      kv_vb_auto_delete_count     7.0.0 gauge

      Cumulative count of documents auto-deleted due to NRU ejection (Ephemeral Buckets only)

      kv_vb_bloom_filter_memory_bytes     7.1.0 gauge / bytes

      The memory usage in bytes of the per-vBucket Bloom filters

      kv_vb_checkpoint_memory_bytes     7.0.0 gauge / bytes

      Total memory in checkpoints, sum of kv_vb__checkpoint_memory_overhead_bytes and kv_vb_checkpoint_memory_queue_bytes

      kv_vb_checkpoint_memory_overhead_bytes     7.0.0 gauge / bytes

      Checkpoints memory overhead. That is the sum of kv_vb_checkpoint_memory_overhead_index_bytes and kv_vb_checkpoint_memory_overhead_queue_bytes.

      kv_vb_checkpoint_memory_overhead_index_bytes     7.1.0 gauge / bytes

      Memory overhead in the checkpoints key-index. For every index entry, that accounts the internal structure allocation plus the key-size.

      kv_vb_checkpoint_memory_overhead_queue_bytes     7.1.0 gauge / bytes

      Memory overhead in the checkpoints internal items queue. For every item in the queue, that accounts the internal structure allocation for holding the item's reference.

      kv_vb_checkpoint_memory_queue_bytes     7.1.0 gauge / bytes

      Total memory of all the items queued in checkpoints. For every item in the queue, that accounts the item's key, metadata and value size. The value allocation may have shared ownership HashTable and DCP Stream readyQ.

      kv_vb_curr_items     7.0.0 gauge

      Count of alive (non-deleted) items in the vbucket, including non-resident items

      kv_vb_dm_mem_used_bytes     7.2.1 gauge / bytes

      The memory usage in bytes of the per-VBucket Durability Monitor (in-progress SyncWrites)

      kv_vb_dm_num_tracked     7.2.1 gauge

      The number of items tracked in the per-VBucket Durability Monitor (in-progress SyncWrites)

      kv_vb_eject     7.0.0 gauge

      Cumulative count of the number of items whose values have been ejected for this vBucket

      kv_vb_expired     7.0.0 gauge

      Cumulative count of the number of items which have been expired for this vBucket

      kv_vb_ht_item_memory_bytes     7.1.0 gauge / bytes

      The memory usage of items stored in the HashTable

      kv_vb_ht_item_memory_uncompressed_bytes     7.1.0 gauge / bytes

      The memory usage of items stored in the HashTable, if the values were not compressed

      kv_vb_ht_memory_bytes     7.0.0 gauge / bytes

      Memory overhead of the HashTable

      kv_vb_ht_tombstone_purged_count     7.0.0 gauge

      Number of purged tombstones (Ephemeral)

      kv_vb_max_history_disk_size_bytes     7.2.0 gauge / bytes

      The total size of history stored per-vBucket (the largest size reported by any vBucket)

      kv_vb_mem_freed_by_checkpoint_item_expel_bytes     7.1.0 gauge / bytes

      Memory recovered from Checkpoint by expelling clean items (i.e. items processed by all cursors) from the queue

      kv_vb_mem_freed_by_checkpoint_removal_bytes     7.1.0 gauge / bytes

      Amount of memory freed through ckpt removal

      kv_vb_meta_data_disk_bytes     7.0.0 gauge / bytes

      Estimate of how much metadata has been written to disk since startup

      kv_vb_meta_data_memory_bytes     7.0.0 gauge / bytes

      Total memory used by meta data, including the key

      kv_vb_num_non_resident     7.0.0 gauge

      The number of non-resident items

      kv_vb_ops_create     7.0.0 gauge

      Number of operations where an item has been flushed to disk that did not previously exist

      kv_vb_ops_delete     7.0.0 gauge

      Number of operations where a delete has been persisted

      kv_vb_ops_get     7.0.0 gauge

      Number of successful front-end get operations

      kv_vb_ops_reject     7.0.0 gauge

      Number of fatal errors in persisting a mutation (including deletion)

      kv_vb_ops_update     7.0.0 gauge

      Number of operations where a new version of an item has been persisted

      kv_vb_perc_mem_resident_ratio     7.0.0 gauge / ratio

      Percentage of items which are resident in memory

      kv_vb_queue_age_seconds     7.0.0 gauge / seconds

      Sum of disk queue item age in seconds

      kv_vb_queue_drain     7.0.0 gauge

      Total drained items

      kv_vb_queue_fill     7.0.0 gauge

      Total items enqueued on disk queues

      kv_vb_queue_memory_bytes     7.0.0 gauge / bytes

      Total memory used by the disk queues

      kv_vb_queue_pending_bytes     7.0.0 gauge / bytes

      Total bytes of pending writes in the disk queue

      kv_vb_queue_size     7.0.0 gauge

      Number of items in the disk queues

      kv_vb_rollback_item_count     7.0.0 gauge

      Total number of mutations discarded during rollback

      kv_vb_seqlist_count     7.0.0 gauge

      Number of items in the sequence list

      kv_vb_seqlist_deleted_count     7.0.0 gauge

      Number of deleted items in the sequence list

      kv_vb_seqlist_purged_count     7.0.0 gauge

      Number of tombstones purged from the sequence list

      kv_vb_seqlist_read_range_count     7.0.0 gauge

      Number of sequence numbers visible according to the sequence list read range

      kv_vb_seqlist_stale_count     7.0.0 gauge

      Number of stale items in the sequence list

      kv_vb_seqlist_stale_metadata_bytes     7.0.0 gauge / bytes

      Total bytes of stale metadata (key + fixed metadata) in the sequence list

      kv_vb_seqlist_stale_value_bytes     7.0.0 gauge / bytes

      Total bytes of stale values in the sequence list

      kv_vb_sync_write_aborted_count     7.0.0 gauge

      Total number of aborted SyncWrites

      kv_vb_sync_write_accepted_count     7.0.0 gauge

      Total number of accepted SyncWrites (in-progress, aborted or committed)

      kv_vb_sync_write_committed_count     7.0.0 gauge

      Total number of comitted SyncWrites

      kv_written_bytes     7.0.0 gauge / bytes

      The number bytes sent to all connections bound to this bucket