ScyllaDB University LIVE, FREE Virtual Training Event | March 21
Register for Free
ScyllaDB Documentation Logo Documentation
  • Server
  • Cloud
  • Tools
    • ScyllaDB Manager
    • ScyllaDB Monitoring Stack
    • ScyllaDB Operator
  • Drivers
    • CQL Drivers
    • DynamoDB Drivers
  • Resources
    • ScyllaDB University
    • Community Forum
    • Tutorials
Download
ScyllaDB Docs ScyllaDB Open Source Reference Metrics (BETA)

Caution

You're viewing documentation for a previous version. Switch to the latest stable version.

Metrics (BETA)Copy

LogallocCopy

scyllalsa_total_space_bytesCopy

Holds a current size of allocated memory in bytes.

  • Type: gauge

  • Component: lsa

  • Key: total_space_bytes

scyllalsa_used_space_bytesCopy

Holds a current amount of used memory in bytes.

  • Type: gauge

  • Component: lsa

  • Key: used_space_bytes

scyllalsa_small_objects_total_space_bytesCopy

Holds a current size of small objects memory region in bytes.

  • Type: gauge

  • Component: lsa

  • Key: small_objects_total_space_bytes

scyllalsa_small_objects_used_space_bytesCopy

Holds a current amount of used small objects memory in bytes.

  • Type: gauge

  • Component: lsa

  • Key: small_objects_used_space_bytes

scyllalsa_large_objects_total_space_bytesCopy

Holds a current size of allocated non-LSA memory.

  • Type: gauge

  • Component: lsa

  • Key: large_objects_total_space_bytes

scyllalsa_non_lsa_used_space_bytesCopy

Holds a current amount of used non-LSA memory.

  • Type: gauge

  • Component: lsa

  • Key: non_lsa_used_space_bytes

scyllalsa_free_spaceCopy

Holds a current amount of free memory that is under lsa control.

  • Type: gauge

  • Component: lsa

  • Key: free_space

scyllalsa_occupancyCopy

Holds a current portion (in percents) of the used memory.

  • Type: gauge

  • Component: lsa

  • Key: occupancy

scyllalsa_segments_compactedCopy

Counts a number of compacted segments.

  • Type: counter

  • Component: lsa

  • Key: segments_compacted

scyllalsa_memory_compactedCopy

Counts number of bytes which were copied as part of segment compaction.

  • Type: counter

  • Component: lsa

  • Key: memory_compacted

scyllalsa_memory_allocatedCopy

Counts number of bytes which were requested from LSA.

  • Type: counter

  • Component: lsa

  • Key: memory_allocated

scyllalsa_memory_evictedCopy

Counts number of bytes which were evicted.

  • Type: counter

  • Component: lsa

  • Key: memory_evicted

scyllalsa_memory_freedCopy

Counts number of bytes which were requested to be freed in LSA.

  • Type: counter

  • Component: lsa

  • Key: memory_freed

Row levelCopy

scyllarepair_tx_row_nrCopy

Total number of rows sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_row_nr

scyllarepair_rx_row_nrCopy

Total number of rows received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_row_nr

scyllarepair_tx_row_bytesCopy

Total bytes of rows sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_row_bytes

scyllarepair_rx_row_bytesCopy

Total bytes of rows received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_row_bytes

scyllarepair_tx_hashes_nrCopy

Total number of row hashes sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_hashes_nr

scyllarepair_rx_hashes_nrCopy

Total number of row hashes received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_hashes_nr

scyllarepair_row_from_disk_nrCopy

Total number of rows read from disk on this shard.

  • Type: counter

  • Component: repair

  • Key: row_from_disk_nr

scyllarepair_row_from_disk_bytesCopy

Total bytes of rows read from disk on this shard.

  • Type: counter

  • Component: repair

  • Key: row_from_disk_bytes

Batchlog managerCopy

scyllabatchlog_manager_total_write_replay_attemptsCopy

Counts write operations issued in a batchlog replay flow. The high value of this metric indicates that we have a long batch replay list.

  • Type: counter

  • Component: batchlog_manager

  • Key: total_write_replay_attempts

ViewCopy

scyllacolumn_family_view_updates_pushed_remoteCopy

Number of updates (mutations) pushed to remote view replicas

  • Type: total_operations

  • Component: column_family

  • Key: view_updates_pushed_remote

scyllacolumn_family_view_updates_failed_remoteCopy

Number of updates (mutations) that failed to be pushed to remote view replicas

  • Type: total_operations

  • Component: column_family

  • Key: view_updates_failed_remote

scyllacolumn_family_view_updates_pushed_localCopy

Number of updates (mutations) pushed to local view replicas

  • Type: total_operations

  • Component: column_family

  • Key: view_updates_pushed_local

scyllacolumn_family_view_updates_failed_localCopy

Number of updates (mutations) that failed to be pushed to local view replicas

  • Type: total_operations

  • Component: column_family

  • Key: view_updates_failed_local

scyllacolumn_family_view_updates_pendingCopy

Number of updates pushed to view and are still to be completed

  • Type: gauge

  • Component: column_family

  • Key: view_updates_pending

scyllaview_builder_pending_bookkeeping_opsCopy

Number of tasks waiting to perform bookkeeping operations

  • Type: gauge

  • Component: view_builder

  • Key: pending_bookkeeping_ops

scyllaview_builder_steps_performedCopy

Number of performed build steps.

  • Type: counter

  • Component: view_builder

  • Key: steps_performed

scyllaview_builder_steps_failedCopy

Number of failed build steps.

  • Type: counter

  • Component: view_builder

  • Key: steps_failed

scyllaview_builder_builds_in_progressCopy

Number of currently active view builds.

  • Type: gauge

  • Component: view_builder

  • Key: builds_in_progress

TtlCopy

scyllaexpiration_scan_passesCopy

number of passes over the database

  • Type: total_operations

  • Component: expiration

  • Key: scan_passes

scyllaexpiration_scan_tableCopy

number of table scans (counting each scan of each table that enabled expiration)

  • Type: total_operations

  • Component: expiration

  • Key: scan_table

scyllaexpiration_items_deletedCopy

number of items deleted after expiration

  • Type: total_operations

  • Component: expiration

  • Key: items_deleted

scyllaexpiration_secondary_ranges_scannedCopy

number of token ranges scanned by this node while their primary owner was down

  • Type: total_operations

  • Component: expiration

  • Key: secondary_ranges_scanned

Storage serviceCopy

scyllanode_operation_modeCopy

The operation mode of the current node. UNKNOWN = 0, STARTING = 1, JOINING = 2, NORMAL = 3, LEAVING = 4, DECOMMISSIONED = 5, DRAINING = 6, DRAINED = 7, MOVING = 8, MAINTENANCE = 9

  • Type: gauge

  • Component: node

  • Key: operation_mode

Rate limiterCopy

scyllaper_partition_rate_limiter_allocationsCopy

Number of times a entry was allocated over an empty/expired entry.

  • Type: counter

  • Component: per_partition_rate_limiter

  • Key: allocations

scyllaper_partition_rate_limiter_successful_lookupsCopy

Number of times a lookup returned an already allocated entry.

  • Type: counter

  • Component: per_partition_rate_limiter

  • Key: successful_lookups

scyllaper_partition_rate_limiter_failed_allocationsCopy

Number of times the rate limiter gave up trying to allocate.

  • Type: counter

  • Component: per_partition_rate_limiter

  • Key: failed_allocations

scyllaper_partition_rate_limiter_probe_countCopy

Number of probes made during lookups.

  • Type: counter

  • Component: per_partition_rate_limiter

  • Key: probe_count

scyllaper_partition_rate_limiter_load_factorCopy

Current load factor of the hash table (upper bound, may be overestimated).

  • Type: gauge

  • Component: per_partition_rate_limiter

  • Key: load_factor

RepairCopy

scyllanode_ops_finished_percentageCopy

Finished percentage of node operation on this shard

  • Type: gauge

  • Component: node_ops

  • Key: finished_percentage

Row cacheCopy

scyllacache_bytes_usedCopy

current bytes used by the cache out of the total size of memory

  • Type: gauge

  • Component: cache

  • Key: bytes_used

scyllacache_bytes_totalCopy

total size of memory for the cache

  • Type: gauge

  • Component: cache

  • Key: bytes_total

scyllacache_partition_hitsCopy

number of partitions needed by reads and found in cache

  • Type: counter

  • Component: cache

  • Key: partition_hits

scyllacache_partition_missesCopy

number of partitions needed by reads and missing in cache

  • Type: counter

  • Component: cache

  • Key: partition_misses

scyllacache_partition_insertionsCopy

total number of partitions added to cache

  • Type: counter

  • Component: cache

  • Key: partition_insertions

scyllacache_row_hitsCopy

total number of rows needed by reads and found in cache

  • Type: counter

  • Component: cache

  • Key: row_hits

scyllacache_dummy_row_hitsCopy

total number of dummy rows touched by reads in cache

  • Type: counter

  • Component: cache

  • Key: dummy_row_hits

scyllacache_row_missesCopy

total number of rows needed by reads and missing in cache

  • Type: counter

  • Component: cache

  • Key: row_misses

scyllacache_row_insertionsCopy

total number of rows added to cache

  • Type: counter

  • Component: cache

  • Key: row_insertions

scyllacache_row_evictionsCopy

total number of rows evicted from cache

  • Type: counter

  • Component: cache

  • Key: row_evictions

scyllacache_row_removalsCopy

total number of invalidated rows

  • Type: counter

  • Component: cache

  • Key: row_removals

scyllacache_rows_dropped_by_tombstonesCopy

Number of rows dropped in cache by a tombstone write

  • Type: counter

  • Component: cache

  • Key: rows_dropped_by_tombstones

scyllacache_rows_compacted_with_tombstonesCopy

Number of rows scanned during write of a tombstone for the purpose of compaction in cache

  • Type: counter

  • Component: cache

  • Key: rows_compacted_with_tombstones

scyllacache_static_row_insertionsCopy

total number of static rows added to cache

  • Type: counter

  • Component: cache

  • Key: static_row_insertions

scyllacache_concurrent_misses_same_keyCopy

total number of operation with misses same key

  • Type: counter

  • Component: cache

  • Key: concurrent_misses_same_key

scyllacache_partition_mergesCopy

total number of partitions merged

  • Type: counter

  • Component: cache

  • Key: partition_merges

scyllacache_partition_evictionsCopy

total number of evicted partitions

  • Type: counter

  • Component: cache

  • Key: partition_evictions

scyllacache_partition_removalsCopy

total number of invalidated partitions

  • Type: counter

  • Component: cache

  • Key: partition_removals

scyllacache_mispopulationsCopy

number of entries not inserted by reads

  • Type: counter

  • Component: cache

  • Key: mispopulations

scyllacache_partitionsCopy

total number of cached partitions

  • Type: gauge

  • Component: cache

  • Key: partitions

scyllacache_rowsCopy

total number of cached rows

  • Type: gauge

  • Component: cache

  • Key: rows

scyllacache_readsCopy

number of started reads

  • Type: counter

  • Component: cache

  • Key: reads

scyllacache_reads_with_missesCopy

number of reads which had to read from sstables

  • Type: counter

  • Component: cache

  • Key: reads_with_misses

scyllacache_active_readsCopy

number of currently active reads

  • Type: gauge

  • Component: cache

  • Key: active_reads

scyllacache_sstable_reader_recreationsCopy

number of times sstable reader was recreated due to memtable flush

  • Type: counter

  • Component: cache

  • Key: sstable_reader_recreations

scyllacache_sstable_partition_skipsCopy

number of times sstable reader was fast forwarded across partitions

  • Type: counter

  • Component: cache

  • Key: sstable_partition_skips

scyllacache_sstable_row_skipsCopy

number of times sstable reader was fast forwarded within a partition

  • Type: counter

  • Component: cache

  • Key: sstable_row_skips

scyllacache_pinned_dirty_memory_overloadCopy

amount of pinned bytes that we tried to unpin over the limit. This should sit constantly at 0, and any number different than 0 is indicative of a bug

  • Type: counter

  • Component: cache

  • Key: pinned_dirty_memory_overload

scyllacache_rows_processed_from_memtableCopy

total number of rows in memtables which were processed during cache update on memtable flush

  • Type: counter

  • Component: cache

  • Key: rows_processed_from_memtable

scyllacache_rows_dropped_from_memtableCopy

total number of rows in memtables which were dropped during cache update on memtable flush

  • Type: counter

  • Component: cache

  • Key: rows_dropped_from_memtable

scyllacache_rows_merged_from_memtableCopy

total number of rows in memtables which were merged with existing rows during cache update on memtable flush

  • Type: counter

  • Component: cache

  • Key: rows_merged_from_memtable

scyllacache_range_tombstone_readsCopy

total amount of range tombstones processed during read

  • Type: counter

  • Component: cache

  • Key: range_tombstone_reads

scyllacache_row_tombstone_readsCopy

total amount of row tombstones processed during read

  • Type: counter

  • Component: cache

  • Key: row_tombstone_reads

scyllacache_rows_compactedCopy

total amount of attempts to compact expired rows during read

  • Type: counter

  • Component: cache

  • Key: rows_compacted

scyllacache_rows_compacted_awayCopy

total amount of compacted and removed rows during read

  • Type: counter

  • Component: cache

  • Key: rows_compacted_away

SstablesCopy

scyllasstables_index_page_cache_hitsCopy

Index page cache requests which were served from cache

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_hits

scyllasstables_index_page_cache_missesCopy

Index page cache requests which had to perform I/O

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_misses

scyllasstables_index_page_cache_evictionsCopy

Total number of index page cache pages which have been evicted

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_evictions

scyllasstables_index_page_cache_populationsCopy

Total number of index page cache pages which were inserted into the cache

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_populations

scyllasstables_index_page_cache_bytesCopy

Total number of bytes cached in the index page cache

  • Type: gauge

  • Component: sstables

  • Key: index_page_cache_bytes

scyllasstables_index_page_cache_bytes_in_stdCopy

Total number of bytes in temporary buffers which live in the std allocator

  • Type: gauge

  • Component: sstables

  • Key: index_page_cache_bytes_in_std

scyllasstables_index_page_hitsCopy

Index page requests which could be satisfied without waiting

  • Type: counter

  • Component: sstables

  • Key: index_page_hits

scyllasstables_index_page_missesCopy

Index page requests which initiated a read from disk

  • Type: counter

  • Component: sstables

  • Key: index_page_misses

scyllasstables_index_page_blocksCopy

Index page requests which needed to wait due to page not being loaded yet

  • Type: counter

  • Component: sstables

  • Key: index_page_blocks

scyllasstables_index_page_evictionsCopy

Index pages which got evicted from memory

  • Type: counter

  • Component: sstables

  • Key: index_page_evictions

scyllasstables_index_page_populationsCopy

Index pages which got populated into memory

  • Type: counter

  • Component: sstables

  • Key: index_page_populations

scyllasstables_index_page_used_bytesCopy

Amount of bytes used by index pages in memory

  • Type: gauge

  • Component: sstables

  • Key: index_page_used_bytes

scyllasstables_pi_cache_hits_l0Copy

Number of requests for promoted index block in state l0 which didn’t have to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_hits_l0

scyllasstables_pi_cache_hits_l1Copy

Number of requests for promoted index block in state l1 which didn’t have to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_hits_l1

scyllasstables_pi_cache_hits_l2Copy

Number of requests for promoted index block in state l2 which didn’t have to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_hits_l2

scyllasstables_pi_cache_misses_l0Copy

Number of requests for promoted index block in state l0 which had to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_misses_l0

scyllasstables_pi_cache_misses_l1Copy

Number of requests for promoted index block in state l1 which had to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_misses_l1

scyllasstables_pi_cache_misses_l2Copy

Number of requests for promoted index block in state l2 which had to go to the page cache

  • Type: counter

  • Component: sstables

  • Key: pi_cache_misses_l2

scyllasstables_pi_cache_populationsCopy

Number of promoted index blocks which got inserted

  • Type: counter

  • Component: sstables

  • Key: pi_cache_populations

scyllasstables_pi_cache_evictionsCopy

Number of promoted index blocks which got evicted

  • Type: counter

  • Component: sstables

  • Key: pi_cache_evictions

scyllasstables_pi_cache_bytesCopy

Number of bytes currently used by cached promoted index blocks

  • Type: gauge

  • Component: sstables

  • Key: pi_cache_bytes

scyllasstables_pi_cache_block_countCopy

Number of promoted index blocks currently cached

  • Type: gauge

  • Component: sstables

  • Key: pi_cache_block_count

scyllasstables_partition_writesCopy

Number of partitions written

  • Type: counter

  • Component: sstables

  • Key: partition_writes

scyllasstables_static_row_writesCopy

Number of static rows written

  • Type: counter

  • Component: sstables

  • Key: static_row_writes

scyllasstables_row_writesCopy

Number of clustering rows written

  • Type: counter

  • Component: sstables

  • Key: row_writes

scyllasstables_cell_writesCopy

Number of cells written

  • Type: counter

  • Component: sstables

  • Key: cell_writes

scyllasstables_tombstone_writesCopy

Number of tombstones written

  • Type: counter

  • Component: sstables

  • Key: tombstone_writes

scyllasstables_range_tombstone_writesCopy

Number of range tombstones written

  • Type: counter

  • Component: sstables

  • Key: range_tombstone_writes

scyllasstables_pi_auto_scale_eventsCopy

Number of promoted index auto-scaling events

  • Type: counter

  • Component: sstables

  • Key: pi_auto_scale_events

scyllasstables_range_tombstone_readsCopy

Number of range tombstones read

  • Type: counter

  • Component: sstables

  • Key: range_tombstone_reads

scyllasstables_row_tombstone_readsCopy

Number of row tombstones read

  • Type: counter

  • Component: sstables

  • Key: row_tombstone_reads

scyllasstables_cell_tombstone_writesCopy

Number of cell tombstones written

  • Type: counter

  • Component: sstables

  • Key: cell_tombstone_writes

scyllasstables_single_partition_readsCopy

Number of single partition flat mutation reads

  • Type: counter

  • Component: sstables

  • Key: single_partition_reads

scyllasstables_range_partition_readsCopy

Number of partition range flat mutation reads

  • Type: counter

  • Component: sstables

  • Key: range_partition_reads

scyllasstables_partition_readsCopy

Number of partitions read

  • Type: counter

  • Component: sstables

  • Key: partition_reads

scyllasstables_partition_seeksCopy

Number of partitions seeked

  • Type: counter

  • Component: sstables

  • Key: partition_seeks

scyllasstables_row_readsCopy

Number of rows read

  • Type: counter

  • Component: sstables

  • Key: row_reads

scyllasstables_capped_local_deletion_timeCopy

Number of SStables with tombstones whose local deletion time was capped at the maximum allowed value in Statistics

  • Type: counter

  • Component: sstables

  • Key: capped_local_deletion_time

scyllasstables_capped_tombstone_deletion_timeCopy

Number of tombstones whose local deletion time was capped at the maximum allowed value

  • Type: counter

  • Component: sstables

  • Key: capped_tombstone_deletion_time

scyllasstables_total_open_for_readingCopy

Counter of sstables open for reading

  • Type: counter

  • Component: sstables

  • Key: total_open_for_reading

scyllasstables_total_open_for_writingCopy

Counter of sstables open for writing

  • Type: counter

  • Component: sstables

  • Key: total_open_for_writing

scyllasstables_currently_open_for_readingCopy

Number of sstables currently open for reading

  • Type: gauge

  • Component: sstables

  • Key: currently_open_for_reading

scyllasstables_currently_open_for_writingCopy

Number of sstables currently open for writing

  • Type: gauge

  • Component: sstables

  • Key: currently_open_for_writing

scyllasstables_total_deletedCopy

Counter of deleted sstables

  • Type: counter

  • Component: sstables

  • Key: total_deleted

scyllasstables_bloom_filter_memory_sizeCopy

Bloom filter memory usage in bytes.

  • Type: gauge

  • Component: sstables

  • Key: bloom_filter_memory_size

GossiperCopy

scyllagossip_heart_beatCopy

Heartbeat of the current Node.

  • Type: counter

  • Component: gossip

  • Key: heart_beat

scyllagossip_liveCopy

How many live nodes the current node sees

  • Type: gauge

  • Component: gossip

  • Key: live

scyllagossip_unreachableCopy

How many unreachable nodes the current node sees

  • Type: gauge

  • Component: gossip

  • Key: unreachable

View update generatorCopy

scyllaview_update_generator_pending_registrationsCopy

Number of tasks waiting to register staging sstables

  • Type: gauge

  • Component: view_update_generator

  • Key: pending_registrations

scyllaview_update_generator_queued_batches_countCopy

Number of sets of sstables queued for view update generation

  • Type: gauge

  • Component: view_update_generator

  • Key: queued_batches_count

scyllaview_update_generator_sstables_to_move_countCopy

Number of sets of sstables which are already processed and wait to be moved from their staging directory

  • Type: gauge

  • Component: view_update_generator

  • Key: sstables_to_move_count

scyllaview_update_generator_sstables_pending_workCopy

Number of bytes remaining to be processed from SSTables for view updates

  • Type: gauge

  • Component: view_update_generator

  • Key: sstables_pending_work

MainCopy

scyllascylladb_current_versionCopy

Current ScyllaDB version.

  • Type: gauge

  • Component: scylladb

  • Key: current_version

Reader concurrency semaphoreCopy

scylladatabase_sstable_read_queue_overloadsCopy

Counts the number of times the sstable read queue was overloaded. A non-zero value indicates that we have to drop read requests because they arrive faster than we can serve them.

  • Type: counter

  • Component: database

  • Key: sstable_read_queue_overloads

scylladatabase_active_readsCopy

Holds the number of currently active read operations.

  • Type: gauge

  • Component: database

  • Key: active_reads

scylladatabase_reads_memory_consumptionCopy

Holds the amount of memory consumed by current read operations.

  • Type: gauge

  • Component: database

  • Key: reads_memory_consumption

scylladatabase_queued_readsCopy

Holds the number of currently queued read operations.

  • Type: gauge

  • Component: database

  • Key: queued_reads

scylladatabase_paused_readsCopy

The number of currently active reads that are temporarily paused.

  • Type: gauge

  • Component: database

  • Key: paused_reads

scylladatabase_paused_reads_permit_based_evictionsCopy

The number of paused reads evicted to free up permits. Permits are required for new reads to start, and the database will evict paused reads (if any) to be able to admit new ones, if there is a shortage of permits.

  • Type: counter

  • Component: database

  • Key: paused_reads_permit_based_evictions

scylladatabase_reads_shed_due_to_overloadCopy

The number of reads shed because the admission queue reached its max capacity. When the queue is full, excessive reads are shed to avoid overload.

  • Type: counter

  • Component: database

  • Key: reads_shed_due_to_overload

scylladatabase_disk_readsCopy

Holds the number of currently active disk read operations.

  • Type: gauge

  • Component: database

  • Key: disk_reads

scylladatabase_sstables_readCopy

Holds the number of currently read sstables.

  • Type: gauge

  • Component: database

  • Key: sstables_read

scylladatabase_total_readsCopy

Counts the total number of successful user reads on this shard.

  • Type: counter

  • Component: database

  • Key: total_reads

scylladatabase_total_reads_failedCopy

Counts the total number of failed user read operations. Add the total_reads to this value to get the total amount of reads issued on this shard.

  • Type: counter

  • Component: database

  • Key: total_reads_failed

ManagerCopy

scyllagroup_name_size_of_hints_in_progressCopy

Size of hinted mutations that are scheduled to be written.

  • Type: gauge

  • Component: group_name

  • Key: size_of_hints_in_progress

scyllagroup_name_writtenCopy

Number of successfully written hints.

  • Type: counter

  • Component: group_name

  • Key: written

scyllagroup_name_errorsCopy

Number of errors during hints writes.

  • Type: counter

  • Component: group_name

  • Key: errors

scyllagroup_name_droppedCopy

Number of dropped hints.

  • Type: counter

  • Component: group_name

  • Key: dropped

scyllagroup_name_sentCopy

Number of sent hints.

  • Type: counter

  • Component: group_name

  • Key: sent

scyllagroup_name_discardedCopy

Number of hints that were discarded during sending (too old, schema changed, etc.).

  • Type: counter

  • Component: group_name

  • Key: discarded

scyllagroup_name_send_errorsCopy

Number of unexpected errors during sending, sending will be retried later

  • Type: counter

  • Component: group_name

  • Key: send_errors

scyllagroup_name_corrupted_filesCopy

Number of hints files that were discarded during sending because the file was corrupted.

  • Type: counter

  • Component: group_name

  • Key: corrupted_files

scyllagroup_name_pending_drainsCopy

Number of tasks waiting in the queue for draining hints

  • Type: gauge

  • Component: group_name

  • Key: pending_drains

scyllagroup_name_pending_sendsCopy

Number of tasks waiting in the queue for sending a hint

  • Type: gauge

  • Component: group_name

  • Key: pending_sends

Compaction managerCopy

scyllacompaction_manager_compactionsCopy

Holds the number of currently active compactions.

  • Type: gauge

  • Component: compaction_manager

  • Key: compactions

scyllacompaction_manager_pending_compactionsCopy

Holds the number of compaction tasks waiting for an opportunity to run.

  • Type: gauge

  • Component: compaction_manager

  • Key: pending_compactions

scyllacompaction_manager_completed_compactionsCopy

Holds the number of completed compaction tasks.

  • Type: counter

  • Component: compaction_manager

  • Key: completed_compactions

scyllacompaction_manager_failed_compactionsCopy

Holds the number of failed compaction tasks.

  • Type: counter

  • Component: compaction_manager

  • Key: failed_compactions

scyllacompaction_manager_postponed_compactionsCopy

Holds the number of tables with postponed compaction.

  • Type: gauge

  • Component: compaction_manager

  • Key: postponed_compactions

scyllacompaction_manager_backlogCopy

Holds the sum of compaction backlog for all tables in the system.

  • Type: gauge

  • Component: compaction_manager

  • Key: backlog

scyllacompaction_manager_normalized_backlogCopy

Holds the sum of normalized compaction backlog for all tables in the system. Backlog is normalized by dividing backlog by shard’s available memory.

  • Type: gauge

  • Component: compaction_manager

  • Key: normalized_backlog

scyllacompaction_manager_validation_errorsCopy

Holds the number of encountered validation errors.

  • Type: counter

  • Component: compaction_manager

  • Key: validation_errors

Raft group0Copy

scyllaraft_group0_statusCopy

status of the raft group, 1 - normal, 2 - aborted

  • Type: gauge

  • Component: raft_group0

  • Key: status

Forward serviceCopy

scyllaforward_service_requests_dispatched_to_other_nodesCopy

how many forward requests were dispatched to other nodes

  • Type: total_operations

  • Component: forward_service

  • Key: requests_dispatched_to_other_nodes

scyllaforward_service_requests_dispatched_to_own_shardsCopy

how many forward requests were dispatched to local shards

  • Type: total_operations

  • Component: forward_service

  • Key: requests_dispatched_to_own_shards

scyllaforward_service_requests_executedCopy

how many forward requests were executed

  • Type: total_operations

  • Component: forward_service

  • Key: requests_executed

Tablet allocatorCopy

scyllagroup_name_callsCopy

number of calls to the load balancer

  • Type: counter

  • Component: group_name

  • Key: calls

scyllagroup_name_migrations_producedCopy

number of migrations produced by the load balancer

  • Type: counter

  • Component: group_name

  • Key: migrations_produced

scyllagroup_name_migrations_skippedCopy

number of migrations skipped by the load balancer due to load limits

  • Type: counter

  • Component: group_name

  • Key: migrations_skipped

scyllagroup_name_loadCopy

node load during last load balancing

  • Type: gauge

  • Component: group_name

  • Key: load

scyllagroup_name_resizes_emittedCopy

number of resizes produced by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_emitted

scyllagroup_name_resizes_revokedCopy

number of resizes revoked by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_revoked

scyllagroup_name_resizes_finalizedCopy

number of resizes finalized by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_finalized

StatsCopy

scyllaalternator_operationCopy

number of operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: operation

scyllaalternator_op_latencyCopy

Latency histogram of an operation via Alternator API

  • Type: histogram

  • Component: alternator

  • Key: op_latency

scyllaalternator_op_latency_summaryCopy

Latency summary of an operation via Alternator API

  • Type: summary

  • Component: alternator

  • Key: op_latency_summary

scyllaalternator_unsupported_operationsCopy

number of unsupported operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: unsupported_operations

scyllaalternator_total_operationsCopy

number of total operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: total_operations

scyllaalternator_reads_before_writeCopy

number of performed read-before-write operations

  • Type: total_operations

  • Component: alternator

  • Key: reads_before_write

scyllaalternator_write_using_lwtCopy

number of writes that used LWT

  • Type: total_operations

  • Component: alternator

  • Key: write_using_lwt

scyllaalternator_shard_bounce_for_lwtCopy

number writes that had to be bounced from this shard because of LWT requirements

  • Type: total_operations

  • Component: alternator

  • Key: shard_bounce_for_lwt

scyllaalternator_requests_blocked_memoryCopy

Counts a number of requests blocked due to memory pressure.

  • Type: total_operations

  • Component: alternator

  • Key: requests_blocked_memory

scyllaalternator_requests_shedCopy

Counts a number of requests shed due to overload.

  • Type: total_operations

  • Component: alternator

  • Key: requests_shed

scyllaalternator_filtered_rows_read_totalCopy

number of rows read during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_read_total

scyllaalternator_filtered_rows_matched_totalCopy

number of rows read and matched during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_matched_total

scyllaalternator_filtered_rows_dropped_totalCopy

number of rows read and dropped during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_dropped_total

ClientCopy

scyllas3_nr_connectionsCopy

Total number of connections

  • Type: gauge

  • Component: s3

  • Key: nr_connections

scyllas3_nr_active_connectionsCopy

Total number of connections with running requests

  • Type: gauge

  • Component: s3

  • Key: nr_active_connections

scyllas3_total_new_connectionsCopy

Total number of new connections created so far

  • Type: counter

  • Component: s3

  • Key: total_new_connections

scyllas3_total_read_requestsCopy

Total number of object read requests

  • Type: counter

  • Component: s3

  • Key: total_read_requests

scyllas3_total_write_requestsCopy

Total number of object write requests

  • Type: counter

  • Component: s3

  • Key: total_write_requests

scyllas3_total_read_bytesCopy

Total number of bytes read from objects

  • Type: counter

  • Component: s3

  • Key: total_read_bytes

scyllas3_total_write_bytesCopy

Total number of bytes written to objects

  • Type: counter

  • Component: s3

  • Key: total_write_bytes

scyllas3_total_read_latency_secCopy

Total time spent reading data from objects

  • Type: counter

  • Component: s3

  • Key: total_read_latency_sec

scyllas3_total_write_latency_secCopy

Total time spend writing data to objects

  • Type: counter

  • Component: s3

  • Key: total_write_latency_sec

Trace keyspace helperCopy

scyllatracing_keyspace_helper_tracing_errorsCopy

Counts a number of errors during writing to a system_traces keyspace. One error may cause one or more tracing records to be lost.

  • Type: counter

  • Component: tracing_keyspace_helper

  • Key: tracing_errors

scyllatracing_keyspace_helper_bad_column_family_errorsCopy

Counts a number of times write failed due to one of the tables in the system_traces keyspace has an incompatible schema. One error may result one or more tracing records to be lost. Non-zero value indicates that the administrator has to take immediate steps to fix the corresponding schema. The appropriate error message will be printed in the syslog.

  • Type: counter

  • Component: tracing_keyspace_helper

  • Key: bad_column_family_errors

Stream sessionCopy

Stream managerCopy

scyllastreaming_total_incoming_bytesCopy

Total number of bytes received on this shard.

  • Type: counter

  • Component: streaming

  • Key: total_incoming_bytes

scyllastreaming_total_outgoing_bytesCopy

Total number of bytes sent on this shard.

  • Type: counter

  • Component: streaming

  • Key: total_outgoing_bytes

scyllastreaming_finished_percentageCopy

Finished percentage of node operation on this shard

  • Type: gauge

  • Component: streaming

  • Key: finished_percentage

Wasm instance cacheCopy

scyllauser_functions_cache_hitsCopy

The number of user defined function cache hits

  • Type: counter

  • Component: user_functions

  • Key: cache_hits

scyllauser_functions_cache_missesCopy

The number of user defined functions loaded

  • Type: counter

  • Component: user_functions

  • Key: cache_misses

scyllauser_functions_cache_blocksCopy

The number of times a user defined function waited for an instance

  • Type: counter

  • Component: user_functions

  • Key: cache_blocks

scyllauser_functions_cache_instace_count_anyCopy

The total number of cached wasm instances, instances in use and empty instances

  • Type: gauge

  • Component: user_functions

  • Key: cache_instace_count_any

scyllauser_functions_cache_total_sizeCopy

The total size of instances stored in the user defined function cache

  • Type: gauge

  • Component: user_functions

  • Key: cache_total_size

Was this page helpful?

PREVIOUS
API Reference (BETA)
NEXT
ScyllaDB FAQ
  • Create an issue
  • Edit this page

On this page

  • Metrics (BETA)
    • Logalloc
    • Row level
    • Batchlog manager
    • View
    • Ttl
    • Storage service
    • Rate limiter
    • Repair
    • Row cache
    • Sstables
    • Gossiper
    • View update generator
    • Main
    • Reader concurrency semaphore
    • Manager
    • Compaction manager
    • Raft group0
    • Forward service
    • Tablet allocator
    • Stats
    • Client
    • Trace keyspace helper
    • Stream session
    • Stream manager
    • Wasm instance cache
ScyllaDB Open Source
  • 6.0
    • 6.2
    • 6.1
    • 6.0
    • 5.4
    • 5.2
    • 5.1
  • Getting Started
    • Install ScyllaDB
      • Launch ScyllaDB on AWS
      • Launch ScyllaDB on GCP
      • Launch ScyllaDB on Azure
      • ScyllaDB Web Installer for Linux
      • Install ScyllaDB Linux Packages
      • Install ScyllaDB Without root Privileges
      • Air-gapped Server Installation
      • ScyllaDB Housekeeping and how to disable it
      • ScyllaDB Developer Mode
    • Configure ScyllaDB
    • ScyllaDB Configuration Reference
    • ScyllaDB Requirements
      • System Requirements
      • OS Support by Linux Distributions and Version
      • Cloud Instance Recommendations
      • ScyllaDB in a Shared Environment
    • Migrate to ScyllaDB
      • Migration Process from Cassandra to Scylla
      • Scylla and Apache Cassandra Compatibility
      • Migration Tools Overview
    • Integration Solutions
      • Integrate Scylla with Spark
      • Integrate Scylla with KairosDB
      • Integrate ScyllaDB with Presto
      • Integrate Scylla with Elasticsearch
      • Integrate Scylla with Kubernetes
      • Integrate Scylla with the JanusGraph Graph Data System
      • Integrate Scylla with DataDog
      • Integrate Scylla with Kafka
      • Integrate Scylla with IOTA Chronicle
      • Integrate Scylla with Spring
      • Shard-Aware Kafka Connector for Scylla
      • Install Scylla with Ansible
      • Integrate Scylla with Databricks
      • Integrate Scylla with Jaeger Server
      • Integrate Scylla with MindsDB
    • Tutorials
  • ScyllaDB for Administrators
    • Administration Guide
    • Procedures
      • Cluster Management
      • Backup & Restore
      • Change Configuration
      • Maintenance
      • Best Practices
      • Benchmarking Scylla
      • Migrate from Cassandra to Scylla
      • Disable Housekeeping
    • Security
      • ScyllaDB Security Checklist
      • Enable Authentication
      • Enable and Disable Authentication Without Downtime
      • Creating a Custom Superuser
      • Generate a cqlshrc File
      • Reset Authenticator Password
      • Enable Authorization
      • Grant Authorization CQL Reference
      • Certificate-based Authentication
      • Role Based Access Control (RBAC)
      • Encryption: Data in Transit Client to Node
      • Encryption: Data in Transit Node to Node
      • Generating a self-signed Certificate Chain Using openssl
      • Configure SaslauthdAuthenticator
    • Admin Tools
      • Nodetool Reference
      • CQLSh
      • Admin REST API
      • Tracing
      • Scylla SStable
      • Scylla Types
      • SSTableLoader
      • cassandra-stress
      • SSTabledump
      • SSTableMetadata
      • Scylla Logs
      • Seastar Perftune
      • Virtual Tables
      • Reading mutation fragments
      • Maintenance socket
      • Maintenance mode
    • ScyllaDB Monitoring Stack
    • ScyllaDB Operator
    • ScyllaDB Manager
    • Upgrade Procedures
      • ScyllaDB Versioning
      • ScyllaDB Open Source Upgrade
      • ScyllaDB Open Source to ScyllaDB Enterprise Upgrade
      • ScyllaDB Image
      • ScyllaDB Enterprise
    • System Configuration
      • System Configuration Guide
      • scylla.yaml
      • ScyllaDB Snitches
    • Benchmarking ScyllaDB
    • ScyllaDB Diagnostic Tools
  • ScyllaDB for Developers
    • Develop with ScyllaDB
    • Tutorials and Example Projects
    • Learn to Use ScyllaDB
    • ScyllaDB Alternator
    • ScyllaDB Features
      • Lightweight Transactions
      • Global Secondary Indexes
      • Local Secondary Indexes
      • Materialized Views
      • Counters
      • Change Data Capture
      • Workload Attributes
    • ScyllaDB Drivers
      • Scylla CQL Drivers
      • Scylla DynamoDB Drivers
  • CQL Reference
    • CQLSh: the CQL shell
    • Appendices
    • Compaction
    • Consistency Levels
    • Consistency Level Calculator
    • Data Definition
    • Data Manipulation
      • SELECT
      • INSERT
      • UPDATE
      • DELETE
      • BATCH
    • Data Types
    • Definitions
    • Global Secondary Indexes
    • Expiring Data with Time to Live (TTL)
    • Functions
    • Wasm support for user-defined functions
    • JSON Support
    • Materialized Views
    • Non-Reserved CQL Keywords
    • Reserved CQL Keywords
    • Service Levels
    • ScyllaDB CQL Extensions
  • ScyllaDB Architecture
    • Data Distribution with Tablets
    • ScyllaDB Ring Architecture
    • ScyllaDB Fault Tolerance
    • Consistency Level Console Demo
    • ScyllaDB Anti-Entropy
      • Scylla Hinted Handoff
      • Scylla Read Repair
      • Scylla Repair
    • SSTable
      • ScyllaDB SSTable - 2.x
      • ScyllaDB SSTable - 3.x
    • Compaction Strategies
    • Raft Consensus Algorithm in ScyllaDB
  • Troubleshooting ScyllaDB
    • Errors and Support
      • Report a Scylla problem
      • Error Messages
      • Change Log Level
    • ScyllaDB Startup
      • Ownership Problems
      • Scylla will not Start
      • Scylla Python Script broken
    • Upgrade
      • Inaccessible configuration files after ScyllaDB upgrade
    • Cluster and Node
      • Handling Node Failures
      • Failure to Add, Remove, or Replace a Node
      • Failed Decommission Problem
      • Cluster Timeouts
      • Node Joined With No Data
      • SocketTimeoutException
      • NullPointerException
      • Failed Schema Sync
    • Data Modeling
      • Scylla Large Partitions Table
      • Scylla Large Rows and Cells Table
      • Large Partitions Hunting
      • Failure to Update the Schema
    • Data Storage and SSTables
      • Space Utilization Increasing
      • Disk Space is not Reclaimed
      • SSTable Corruption Problem
      • Pointless Compactions
      • Limiting Compaction
    • CQL
      • Time Range Query Fails
      • COPY FROM Fails
      • CQL Connection Table
    • ScyllaDB Monitor and Manager
      • Manager and Monitoring integration
      • Manager lists healthy nodes as down
  • Knowledge Base
    • Upgrading from experimental CDC
    • Compaction
    • Consistency in ScyllaDB
    • Counting all rows in a table is slow
    • CQL Query Does Not Display Entire Result Set
    • When CQLSh query returns partial results with followed by “More”
    • Run Scylla and supporting services as a custom user:group
    • Customizing CPUSET
    • Decoding Stack Traces
    • Snapshots and Disk Utilization
    • DPDK mode
    • Debug your database with Flame Graphs
    • How to Change gc_grace_seconds for a Table
    • Gossip in Scylla
    • Increase Permission Cache to Avoid Non-paged Queries
    • How does Scylla LWT Differ from Apache Cassandra ?
    • Map CPUs to Scylla Shards
    • Scylla Memory Usage
    • NTP Configuration for Scylla
    • Updating the Mode in perftune.yaml After a ScyllaDB Upgrade
    • POSIX networking for Scylla
    • Scylla consistency quiz for administrators
    • Recreate RAID devices
    • How to Safely Increase the Replication Factor
    • Scylla and Spark integration
    • Increase Scylla resource limits over systemd
    • Scylla Seed Nodes
    • How to Set up a Swap Space
    • Scylla Snapshots
    • Scylla payload sent duplicated static columns
    • Stopping a local repair
    • System Limits
    • How to flush old tombstones from a table
    • Time to Live (TTL) and Compaction
    • Scylla Nodes are Unresponsive
    • Update a Primary Key
    • Using the perf utility with Scylla
    • Configure Scylla Networking with Multiple NIC/IP Combinations
  • Reference
    • AWS Images
    • Azure Images
    • GCP Images
    • Configuration Parameters
    • Glossary
    • Limits
    • API Reference (BETA)
    • Metrics (BETA)
  • ScyllaDB FAQ
  • Contribute to ScyllaDB
  • Alternator: DynamoDB API in Scylla
    • Getting Started With ScyllaDB Alternator
    • ScyllaDB Alternator for DynamoDB users
Docs Tutorials University Contact Us About Us
© 2025, ScyllaDB. All rights reserved. | Terms of Service | Privacy Policy | ScyllaDB, and ScyllaDB Cloud, are registered trademarks of ScyllaDB, Inc.
Last updated on 10 Jul 2025.
Powered by Sphinx 7.4.7 & ScyllaDB Theme 1.8.7
Ask AI
Yes
No
User Slack channel
Community forum
Collapse