Was this page helpful?
Metrics (BETA)¶
Service level controller¶
Describe statement¶
Repair¶
- scyllanode_ops_finished_percentage¶
Finished percentage of node operation on this shard
Type:
gauge
Component:
node_ops
Key:
finished_percentage
Maintenance socket role manager¶
Batchlog manager¶
- scyllabatchlog_manager_total_write_replay_attempts¶
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
Types¶
Reader concurrency semaphore¶
- scylladatabase_sstable_read_queue_overloads¶
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_reads¶
Holds the number of currently active read operations.
Type:
gauge
Component:
database
Key:
active_reads
- scylladatabase_reads_memory_consumption¶
Holds the amount of memory consumed by current read operations.
Type:
gauge
Component:
database
Key:
reads_memory_consumption
- scylladatabase_queued_reads¶
Holds the number of currently queued read operations.
Type:
gauge
Component:
database
Key:
queued_reads
- scylladatabase_paused_reads¶
The number of currently active reads that are temporarily paused.
Type:
gauge
Component:
database
Key:
paused_reads
- scylladatabase_paused_reads_permit_based_evictions¶
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_overload¶
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_reads¶
Holds the number of currently active disk read operations.
Type:
gauge
Component:
database
Key:
disk_reads
- scylladatabase_sstables_read¶
Holds the number of currently read sstables.
Type:
gauge
Component:
database
Key:
sstables_read
- scylladatabase_total_reads¶
Counts the total number of successful user reads on this shard.
Type:
counter
Component:
database
Key:
total_reads
- scylladatabase_total_reads_failed¶
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
Data dictionary¶
Tablet allocator¶
- scyllagroup_name_calls¶
number of calls to the load balancer
Type:
counter
Component:
group_name
Key:
calls
- scyllagroup_name_migrations_produced¶
number of migrations produced by the load balancer
Type:
counter
Component:
group_name
Key:
migrations_produced
- scyllagroup_name_migrations_skipped¶
number of migrations skipped by the load balancer due to load limits
Type:
counter
Component:
group_name
Key:
migrations_skipped
- scyllagroup_name_load¶
node load during last load balancing
Type:
gauge
Component:
group_name
Key:
load
- scyllagroup_name_resizes_emitted¶
number of resizes produced by the load balancer
Type:
counter
Component:
group_name
Key:
resizes_emitted
- scyllagroup_name_resizes_revoked¶
number of resizes revoked by the load balancer
Type:
counter
Component:
group_name
Key:
resizes_revoked
- scyllagroup_name_resizes_finalized¶
number of resizes finalized by the load balancer
Type:
counter
Component:
group_name
Key:
resizes_finalized
Stream manager¶
- scyllastreaming_total_incoming_bytes¶
Total number of bytes received on this shard.
Type:
counter
Component:
streaming
Key:
total_incoming_bytes
- scyllastreaming_total_outgoing_bytes¶
Total number of bytes sent on this shard.
Type:
counter
Component:
streaming
Key:
total_outgoing_bytes
- scyllastreaming_finished_percentage¶
Finished percentage of node operation on this shard
Type:
gauge
Component:
streaming
Key:
finished_percentage
View update generator¶
- scyllaview_update_generator_pending_registrations¶
Number of tasks waiting to register staging sstables
Type:
gauge
Component:
view_update_generator
Key:
pending_registrations
- scyllaview_update_generator_queued_batches_count¶
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_count¶
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_work¶
Number of bytes remaining to be processed from SSTables for view updates
Type:
gauge
Component:
view_update_generator
Key:
sstables_pending_work
Schema¶
Standard role manager¶
Wasm instance cache¶
- scyllauser_functions_cache_hits¶
The number of user defined function cache hits
Type:
counter
Component:
user_functions
Key:
cache_hits
- scyllauser_functions_cache_misses¶
The number of user defined functions loaded
Type:
counter
Component:
user_functions
Key:
cache_misses
- scyllauser_functions_cache_blocks¶
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_any¶
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_size¶
The total size of instances stored in the user defined function cache
Type:
gauge
Component:
user_functions
Key:
cache_total_size
View¶
- scyllacolumn_family_view_updates_pushed_remote¶
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_remote¶
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_local¶
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_local¶
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_pending¶
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_ops¶
Number of tasks waiting to perform bookkeeping operations
Type:
gauge
Component:
view_builder
Key:
pending_bookkeeping_ops
- scyllaview_builder_steps_performed¶
Number of performed build steps.
Type:
counter
Component:
view_builder
Key:
steps_performed
- scyllaview_builder_steps_failed¶
Number of failed build steps.
Type:
counter
Component:
view_builder
Key:
steps_failed
- scyllaview_builder_builds_in_progress¶
Number of currently active view builds.
Type:
gauge
Component:
view_builder
Key:
builds_in_progress
Raft group0¶
- scyllaraft_group0_status¶
status of the raft group, 1 - normal, 2 - aborted
Type:
gauge
Component:
raft_group0
Key:
status
Compaction manager¶
- scyllacompaction_manager_compactions¶
Holds the number of currently active compactions.
Type:
gauge
Component:
compaction_manager
Key:
compactions
- scyllacompaction_manager_pending_compactions¶
Holds the number of compaction tasks waiting for an opportunity to run.
Type:
gauge
Component:
compaction_manager
Key:
pending_compactions
- scyllacompaction_manager_completed_compactions¶
Holds the number of completed compaction tasks.
Type:
counter
Component:
compaction_manager
Key:
completed_compactions
- scyllacompaction_manager_failed_compactions¶
Holds the number of failed compaction tasks.
Type:
counter
Component:
compaction_manager
Key:
failed_compactions
- scyllacompaction_manager_postponed_compactions¶
Holds the number of tables with postponed compaction.
Type:
gauge
Component:
compaction_manager
Key:
postponed_compactions
- scyllacompaction_manager_backlog¶
Holds the sum of compaction backlog for all tables in the system.
Type:
gauge
Component:
compaction_manager
Key:
backlog
- scyllacompaction_manager_normalized_backlog¶
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_errors¶
Holds the number of encountered validation errors.
Type:
counter
Component:
compaction_manager
Key:
validation_errors
Forward service¶
- scyllaforward_service_requests_dispatched_to_other_nodes¶
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_shards¶
how many forward requests were dispatched to local shards
Type:
total_operations
Component:
forward_service
Key:
requests_dispatched_to_own_shards
- scyllaforward_service_requests_executed¶
how many forward requests were executed
Type:
total_operations
Component:
forward_service
Key:
requests_executed
Stream session¶
Stats¶
- scyllaalternator_operation¶
number of operations via Alternator API
Type:
total_operations
Component:
alternator
Key:
operation
- scyllaalternator_op_latency¶
Latency histogram of an operation via Alternator API
Type:
histogram
Component:
alternator
Key:
op_latency
- scyllaalternator_op_latency_summary¶
Latency summary of an operation via Alternator API
Type:
summary
Component:
alternator
Key:
op_latency_summary
- scyllaalternator_unsupported_operations¶
number of unsupported operations via Alternator API
Type:
total_operations
Component:
alternator
Key:
unsupported_operations
- scyllaalternator_total_operations¶
number of total operations via Alternator API
Type:
total_operations
Component:
alternator
Key:
total_operations
- scyllaalternator_reads_before_write¶
number of performed read-before-write operations
Type:
total_operations
Component:
alternator
Key:
reads_before_write
- scyllaalternator_write_using_lwt¶
number of writes that used LWT
Type:
total_operations
Component:
alternator
Key:
write_using_lwt
- scyllaalternator_shard_bounce_for_lwt¶
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_memory¶
Counts a number of requests blocked due to memory pressure.
Type:
total_operations
Component:
alternator
Key:
requests_blocked_memory
- scyllaalternator_requests_shed¶
Counts a number of requests shed due to overload.
Type:
total_operations
Component:
alternator
Key:
requests_shed
- scyllaalternator_filtered_rows_read_total¶
number of rows read during filtering operations
Type:
total_operations
Component:
alternator
Key:
filtered_rows_read_total
- scyllaalternator_filtered_rows_matched_total¶
number of rows read and matched during filtering operations
Type:
total_operations
Component:
alternator
Key:
filtered_rows_matched_total
- scyllaalternator_rcu_total¶
total number of consumed read units, counted as half units
Type:
counter
Component:
alternator
Key:
rcu_total
- scyllaalternator_wcu_total¶
total number of consumed write units, counted as half units
Type:
counter
Component:
alternator
Key:
wcu_total
- scyllaalternator_filtered_rows_dropped_total¶
number of rows read and dropped during filtering operations
Type:
total_operations
Component:
alternator
Key:
filtered_rows_dropped_total
Logalloc¶
- scyllalsa_total_space_bytes¶
Holds a current size of allocated memory in bytes.
Type:
gauge
Component:
lsa
Key:
total_space_bytes
- scyllalsa_used_space_bytes¶
Holds a current amount of used memory in bytes.
Type:
gauge
Component:
lsa
Key:
used_space_bytes
- scyllalsa_small_objects_total_space_bytes¶
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_bytes¶
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_bytes¶
Holds a current size of allocated non-LSA memory.
Type:
gauge
Component:
lsa
Key:
large_objects_total_space_bytes
- scyllalsa_non_lsa_used_space_bytes¶
Holds a current amount of used non-LSA memory.
Type:
gauge
Component:
lsa
Key:
non_lsa_used_space_bytes
- scyllalsa_free_space¶
Holds a current amount of free memory that is under lsa control.
Type:
gauge
Component:
lsa
Key:
free_space
- scyllalsa_occupancy¶
Holds a current portion (in percents) of the used memory.
Type:
gauge
Component:
lsa
Key:
occupancy
- scyllalsa_segments_compacted¶
Counts a number of compacted segments.
Type:
counter
Component:
lsa
Key:
segments_compacted
- scyllalsa_memory_compacted¶
Counts number of bytes which were copied as part of segment compaction.
Type:
counter
Component:
lsa
Key:
memory_compacted
- scyllalsa_memory_allocated¶
Counts number of bytes which were requested from LSA.
Type:
counter
Component:
lsa
Key:
memory_allocated
- scyllalsa_memory_evicted¶
Counts number of bytes which were evicted.
Type:
counter
Component:
lsa
Key:
memory_evicted
- scyllalsa_memory_freed¶
Counts number of bytes which were requested to be freed in LSA.
Type:
counter
Component:
lsa
Key:
memory_freed
Row level¶
- scyllarepair_tx_row_nr¶
Total number of rows sent on this shard.
Type:
counter
Component:
repair
Key:
tx_row_nr
- scyllarepair_rx_row_nr¶
Total number of rows received on this shard.
Type:
counter
Component:
repair
Key:
rx_row_nr
- scyllarepair_tx_row_bytes¶
Total bytes of rows sent on this shard.
Type:
counter
Component:
repair
Key:
tx_row_bytes
- scyllarepair_rx_row_bytes¶
Total bytes of rows received on this shard.
Type:
counter
Component:
repair
Key:
rx_row_bytes
- scyllarepair_tx_hashes_nr¶
Total number of row hashes sent on this shard.
Type:
counter
Component:
repair
Key:
tx_hashes_nr
- scyllarepair_rx_hashes_nr¶
Total number of row hashes received on this shard.
Type:
counter
Component:
repair
Key:
rx_hashes_nr
- scyllarepair_row_from_disk_nr¶
Total number of rows read from disk on this shard.
Type:
counter
Component:
repair
Key:
row_from_disk_nr
- scyllarepair_row_from_disk_bytes¶
Total bytes of rows read from disk on this shard.
Type:
counter
Component:
repair
Key:
row_from_disk_bytes
Gossiper¶
- scyllagossip_heart_beat¶
Heartbeat of the current Node.
Type:
counter
Component:
gossip
Key:
heart_beat
- scyllagossip_live¶
How many live nodes the current node sees
Type:
gauge
Component:
gossip
Key:
live
- scyllagossip_unreachable¶
How many unreachable nodes the current node sees
Type:
gauge
Component:
gossip
Key:
unreachable
Row cache¶
- scyllacache_bytes_used¶
current bytes used by the cache out of the total size of memory
Type:
gauge
Component:
cache
Key:
bytes_used
- scyllacache_bytes_total¶
total size of memory for the cache
Type:
gauge
Component:
cache
Key:
bytes_total
- scyllacache_partition_hits¶
number of partitions needed by reads and found in cache
Type:
counter
Component:
cache
Key:
partition_hits
- scyllacache_partition_misses¶
number of partitions needed by reads and missing in cache
Type:
counter
Component:
cache
Key:
partition_misses
- scyllacache_partition_insertions¶
total number of partitions added to cache
Type:
counter
Component:
cache
Key:
partition_insertions
- scyllacache_row_hits¶
total number of rows needed by reads and found in cache
Type:
counter
Component:
cache
Key:
row_hits
- scyllacache_dummy_row_hits¶
total number of dummy rows touched by reads in cache
Type:
counter
Component:
cache
Key:
dummy_row_hits
- scyllacache_row_misses¶
total number of rows needed by reads and missing in cache
Type:
counter
Component:
cache
Key:
row_misses
- scyllacache_row_insertions¶
total number of rows added to cache
Type:
counter
Component:
cache
Key:
row_insertions
- scyllacache_row_evictions¶
total number of rows evicted from cache
Type:
counter
Component:
cache
Key:
row_evictions
- scyllacache_row_removals¶
total number of invalidated rows
Type:
counter
Component:
cache
Key:
row_removals
- scyllacache_rows_dropped_by_tombstones¶
Number of rows dropped in cache by a tombstone write
Type:
counter
Component:
cache
Key:
rows_dropped_by_tombstones
- scyllacache_rows_compacted_with_tombstones¶
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_insertions¶
total number of static rows added to cache
Type:
counter
Component:
cache
Key:
static_row_insertions
- scyllacache_concurrent_misses_same_key¶
total number of operation with misses same key
Type:
counter
Component:
cache
Key:
concurrent_misses_same_key
- scyllacache_partition_merges¶
total number of partitions merged
Type:
counter
Component:
cache
Key:
partition_merges
- scyllacache_partition_evictions¶
total number of evicted partitions
Type:
counter
Component:
cache
Key:
partition_evictions
- scyllacache_partition_removals¶
total number of invalidated partitions
Type:
counter
Component:
cache
Key:
partition_removals
- scyllacache_mispopulations¶
number of entries not inserted by reads
Type:
counter
Component:
cache
Key:
mispopulations
- scyllacache_partitions¶
total number of cached partitions
Type:
gauge
Component:
cache
Key:
partitions
- scyllacache_rows¶
total number of cached rows
Type:
gauge
Component:
cache
Key:
rows
- scyllacache_reads¶
number of started reads
Type:
counter
Component:
cache
Key:
reads
- scyllacache_reads_with_misses¶
number of reads which had to read from sstables
Type:
counter
Component:
cache
Key:
reads_with_misses
- scyllacache_active_reads¶
number of currently active reads
Type:
gauge
Component:
cache
Key:
active_reads
- scyllacache_sstable_reader_recreations¶
number of times sstable reader was recreated due to memtable flush
Type:
counter
Component:
cache
Key:
sstable_reader_recreations
- scyllacache_sstable_partition_skips¶
number of times sstable reader was fast forwarded across partitions
Type:
counter
Component:
cache
Key:
sstable_partition_skips
- scyllacache_sstable_row_skips¶
number of times sstable reader was fast forwarded within a partition
Type:
counter
Component:
cache
Key:
sstable_row_skips
- scyllacache_pinned_dirty_memory_overload¶
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_memtable¶
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_memtable¶
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_memtable¶
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_reads¶
total amount of range tombstones processed during read
Type:
counter
Component:
cache
Key:
range_tombstone_reads
- scyllacache_row_tombstone_reads¶
total amount of row tombstones processed during read
Type:
counter
Component:
cache
Key:
row_tombstone_reads
- scyllacache_rows_compacted¶
total amount of attempts to compact expired rows during read
Type:
counter
Component:
cache
Key:
rows_compacted
- scyllacache_rows_compacted_away¶
total amount of compacted and removed rows during read
Type:
counter
Component:
cache
Key:
rows_compacted_away
Advanced rpc compressor¶
- scyllarpc_compression_bytes_sent¶
bytes written to RPC connections, before compression
Type:
counter
Component:
rpc_compression
Key:
bytes_sent
- scyllarpc_compression_compressed_bytes_sent¶
bytes written to RPC connections, after compression
Type:
counter
Component:
rpc_compression
Key:
compressed_bytes_sent
- scyllarpc_compression_compressed_bytes_received¶
bytes read from RPC connections, before decompression
Type:
counter
Component:
rpc_compression
Key:
compressed_bytes_received
- scyllarpc_compression_messages_received¶
RPC messages received
Type:
counter
Component:
rpc_compression
Key:
messages_received
- scyllarpc_compression_messages_sent¶
RPC messages sent
Type:
counter
Component:
rpc_compression
Key:
messages_sent
- scyllarpc_compression_bytes_received¶
bytes read from RPC connections, after decompression
Type:
counter
Component:
rpc_compression
Key:
bytes_received
- scyllarpc_compression_compression_cpu_nanos¶
nanoseconds spent on compression
Type:
counter
Component:
rpc_compression
Key:
compression_cpu_nanos
- scyllarpc_compression_decompression_cpu_nanos¶
nanoseconds spent on decompression
Type:
counter
Component:
rpc_compression
Key:
decompression_cpu_nanos
Ttl¶
- scyllaexpiration_scan_passes¶
number of passes over the database
Type:
total_operations
Component:
expiration
Key:
scan_passes
- scyllaexpiration_scan_table¶
number of table scans (counting each scan of each table that enabled expiration)
Type:
total_operations
Component:
expiration
Key:
scan_table
- scyllaexpiration_items_deleted¶
number of items deleted after expiration
Type:
total_operations
Component:
expiration
Key:
items_deleted
- scyllaexpiration_secondary_ranges_scanned¶
number of token ranges scanned by this node while their primary owner was down
Type:
total_operations
Component:
expiration
Key:
secondary_ranges_scanned
Sstables¶
- scyllasstables_index_page_cache_hits¶
Index page cache requests which were served from cache
Type:
counter
Component:
sstables
Key:
index_page_cache_hits
- scyllasstables_index_page_cache_misses¶
Index page cache requests which had to perform I/O
Type:
counter
Component:
sstables
Key:
index_page_cache_misses
- scyllasstables_index_page_cache_evictions¶
Total number of index page cache pages which have been evicted
Type:
counter
Component:
sstables
Key:
index_page_cache_evictions
- scyllasstables_index_page_cache_populations¶
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_bytes¶
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_std¶
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_hits¶
Index page requests which could be satisfied without waiting
Type:
counter
Component:
sstables
Key:
index_page_hits
- scyllasstables_index_page_misses¶
Index page requests which initiated a read from disk
Type:
counter
Component:
sstables
Key:
index_page_misses
- scyllasstables_index_page_blocks¶
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_evictions¶
Index pages which got evicted from memory
Type:
counter
Component:
sstables
Key:
index_page_evictions
- scyllasstables_index_page_populations¶
Index pages which got populated into memory
Type:
counter
Component:
sstables
Key:
index_page_populations
- scyllasstables_index_page_used_bytes¶
Amount of bytes used by index pages in memory
Type:
gauge
Component:
sstables
Key:
index_page_used_bytes
- scyllasstables_pi_cache_hits_l0¶
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_l1¶
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_l2¶
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_l0¶
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_l1¶
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_l2¶
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_populations¶
Number of promoted index blocks which got inserted
Type:
counter
Component:
sstables
Key:
pi_cache_populations
- scyllasstables_pi_cache_evictions¶
Number of promoted index blocks which got evicted
Type:
counter
Component:
sstables
Key:
pi_cache_evictions
- scyllasstables_pi_cache_bytes¶
Number of bytes currently used by cached promoted index blocks
Type:
gauge
Component:
sstables
Key:
pi_cache_bytes
- scyllasstables_pi_cache_block_count¶
Number of promoted index blocks currently cached
Type:
gauge
Component:
sstables
Key:
pi_cache_block_count
- scyllasstables_partition_writes¶
Number of partitions written
Type:
counter
Component:
sstables
Key:
partition_writes
- scyllasstables_static_row_writes¶
Number of static rows written
Type:
counter
Component:
sstables
Key:
static_row_writes
- scyllasstables_row_writes¶
Number of clustering rows written
Type:
counter
Component:
sstables
Key:
row_writes
- scyllasstables_cell_writes¶
Number of cells written
Type:
counter
Component:
sstables
Key:
cell_writes
- scyllasstables_tombstone_writes¶
Number of tombstones written
Type:
counter
Component:
sstables
Key:
tombstone_writes
- scyllasstables_range_tombstone_writes¶
Number of range tombstones written
Type:
counter
Component:
sstables
Key:
range_tombstone_writes
- scyllasstables_pi_auto_scale_events¶
Number of promoted index auto-scaling events
Type:
counter
Component:
sstables
Key:
pi_auto_scale_events
- scyllasstables_range_tombstone_reads¶
Number of range tombstones read
Type:
counter
Component:
sstables
Key:
range_tombstone_reads
- scyllasstables_row_tombstone_reads¶
Number of row tombstones read
Type:
counter
Component:
sstables
Key:
row_tombstone_reads
- scyllasstables_cell_tombstone_writes¶
Number of cell tombstones written
Type:
counter
Component:
sstables
Key:
cell_tombstone_writes
- scyllasstables_single_partition_reads¶
Number of single partition flat mutation reads
Type:
counter
Component:
sstables
Key:
single_partition_reads
- scyllasstables_range_partition_reads¶
Number of partition range flat mutation reads
Type:
counter
Component:
sstables
Key:
range_partition_reads
- scyllasstables_partition_reads¶
Number of partitions read
Type:
counter
Component:
sstables
Key:
partition_reads
- scyllasstables_partition_seeks¶
Number of partitions seeked
Type:
counter
Component:
sstables
Key:
partition_seeks
- scyllasstables_row_reads¶
Number of rows read
Type:
counter
Component:
sstables
Key:
row_reads
- scyllasstables_capped_local_deletion_time¶
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_time¶
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_reading¶
Counter of sstables open for reading
Type:
counter
Component:
sstables
Key:
total_open_for_reading
- scyllasstables_total_open_for_writing¶
Counter of sstables open for writing
Type:
counter
Component:
sstables
Key:
total_open_for_writing
- scyllasstables_currently_open_for_reading¶
Number of sstables currently open for reading
Type:
gauge
Component:
sstables
Key:
currently_open_for_reading
- scyllasstables_currently_open_for_writing¶
Number of sstables currently open for writing
Type:
gauge
Component:
sstables
Key:
currently_open_for_writing
- scyllasstables_total_deleted¶
Counter of deleted sstables
Type:
counter
Component:
sstables
Key:
total_deleted
- scyllasstables_bloom_filter_memory_size¶
Bloom filter memory usage in bytes.
Type:
gauge
Component:
sstables
Key:
bloom_filter_memory_size
Main¶
- scyllascylladb_current_version¶
Current ScyllaDB version.
Type:
gauge
Component:
scylladb
Key:
current_version
Client¶
- scyllas3_nr_connections¶
Total number of connections
Type:
gauge
Component:
s3
Key:
nr_connections
- scyllas3_nr_active_connections¶
Total number of connections with running requests
Type:
gauge
Component:
s3
Key:
nr_active_connections
- scyllas3_total_new_connections¶
Total number of new connections created so far
Type:
counter
Component:
s3
Key:
total_new_connections
- scyllas3_total_read_requests¶
Total number of object read requests
Type:
counter
Component:
s3
Key:
total_read_requests
- scyllas3_total_write_requests¶
Total number of object write requests
Type:
counter
Component:
s3
Key:
total_write_requests
- scyllas3_total_read_bytes¶
Total number of bytes read from objects
Type:
counter
Component:
s3
Key:
total_read_bytes
- scyllas3_total_write_bytes¶
Total number of bytes written to objects
Type:
counter
Component:
s3
Key:
total_write_bytes
- scyllas3_total_read_latency_sec¶
Total time spent reading data from objects
Type:
counter
Component:
s3
Key:
total_read_latency_sec
- scyllas3_total_write_latency_sec¶
Total time spend writing data to objects
Type:
counter
Component:
s3
Key:
total_write_latency_sec
Ldap role manager¶
Rate limiter¶
- scyllaper_partition_rate_limiter_allocations¶
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_lookups¶
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_allocations¶
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_count¶
Number of probes made during lookups.
Type:
counter
Component:
per_partition_rate_limiter
Key:
probe_count
- scyllaper_partition_rate_limiter_load_factor¶
Current load factor of the hash table (upper bound, may be overestimated).
Type:
gauge
Component:
per_partition_rate_limiter
Key:
load_factor
Manager¶
- scyllagroup_name_size_of_hints_in_progress¶
Size of hinted mutations that are scheduled to be written.
Type:
gauge
Component:
group_name
Key:
size_of_hints_in_progress
- scyllagroup_name_written¶
Number of successfully written hints.
Type:
counter
Component:
group_name
Key:
written
- scyllagroup_name_errors¶
Number of errors during hints writes.
Type:
counter
Component:
group_name
Key:
errors
- scyllagroup_name_dropped¶
Number of dropped hints.
Type:
counter
Component:
group_name
Key:
dropped
- scyllagroup_name_sent¶
Number of sent hints.
Type:
counter
Component:
group_name
Key:
sent
- scyllagroup_name_discarded¶
Number of hints that were discarded during sending (too old, schema changed, etc.).
Type:
counter
Component:
group_name
Key:
discarded
- scyllagroup_name_send_errors¶
Number of unexpected errors during sending, sending will be retried later
Type:
counter
Component:
group_name
Key:
send_errors
- scyllagroup_name_corrupted_files¶
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_drains¶
Number of tasks waiting in the queue for draining hints
Type:
gauge
Component:
group_name
Key:
pending_drains
- scyllagroup_name_pending_sends¶
Number of tasks waiting in the queue for sending a hint
Type:
gauge
Component:
group_name
Key:
pending_sends
Trace keyspace helper¶
- scyllatracing_keyspace_helper_tracing_errors¶
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_errors¶
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
Service¶
Storage service¶
- scyllanode_operation_mode¶
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