ScyllaDB University LIVE, FREE Virtual Training Event | March 21
Register for Free
ScyllaDB Documentation Logo Documentation
  • Deployments
    • Cloud
    • Server
  • Tools
    • ScyllaDB Manager
    • ScyllaDB Monitoring Stack
    • ScyllaDB Operator
  • Drivers
    • CQL Drivers
    • DynamoDB Drivers
    • Supported Driver Versions
  • Resources
    • ScyllaDB University
    • Community Forum
    • Tutorials
Install
Ask AI
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)¶

Batchlog manager¶

scylla_batchlog_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

Client¶

scylla_s3_nr_connections¶

Total number of connections

  • Type: gauge

  • Component: s3

  • Key: nr_connections

scylla_s3_nr_active_connections¶

Total number of connections with running requests

  • Type: gauge

  • Component: s3

  • Key: nr_active_connections

scylla_s3_total_new_connections¶

Total number of new connections created so far

  • Type: counter

  • Component: s3

  • Key: total_new_connections

scylla_s3_total_read_requests¶

Total number of object read requests

  • Type: counter

  • Component: s3

  • Key: total_read_requests

scylla_s3_total_write_requests¶

Total number of object write requests

  • Type: counter

  • Component: s3

  • Key: total_write_requests

scylla_s3_total_read_bytes¶

Total number of bytes read from objects

  • Type: counter

  • Component: s3

  • Key: total_read_bytes

scylla_s3_total_write_bytes¶

Total number of bytes written to objects

  • Type: counter

  • Component: s3

  • Key: total_write_bytes

scylla_s3_total_read_latency_sec¶

Total time spent reading data from objects

  • Type: counter

  • Component: s3

  • Key: total_read_latency_sec

scylla_s3_total_write_latency_sec¶

Total time spend writing data to objects

  • Type: counter

  • Component: s3

  • Key: total_write_latency_sec

Compaction manager¶

scylla_compaction_manager_compactions¶

Holds the number of currently active compactions.

  • Type: gauge

  • Component: compaction_manager

  • Key: compactions

scylla_compaction_manager_pending_compactions¶

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

  • Type: gauge

  • Component: compaction_manager

  • Key: pending_compactions

scylla_compaction_manager_completed_compactions¶

Holds the number of completed compaction tasks.

  • Type: counter

  • Component: compaction_manager

  • Key: completed_compactions

scylla_compaction_manager_failed_compactions¶

Holds the number of failed compaction tasks.

  • Type: counter

  • Component: compaction_manager

  • Key: failed_compactions

scylla_compaction_manager_postponed_compactions¶

Holds the number of tables with postponed compaction.

  • Type: gauge

  • Component: compaction_manager

  • Key: postponed_compactions

scylla_compaction_manager_backlog¶

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

  • Type: gauge

  • Component: compaction_manager

  • Key: backlog

scylla_compaction_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

scylla_compaction_manager_validation_errors¶

Holds the number of encountered validation errors.

  • Type: counter

  • Component: compaction_manager

  • Key: validation_errors

Forward service¶

scylla_forward_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

scylla_forward_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

scylla_forward_service_requests_executed¶

how many forward requests were executed

  • Type: total_operations

  • Component: forward_service

  • Key: requests_executed

Gossiper¶

scylla_gossip_heart_beat¶

Heartbeat of the current Node.

  • Type: counter

  • Component: gossip

  • Key: heart_beat

scylla_gossip_live¶

How many live nodes the current node sees

  • Type: gauge

  • Component: gossip

  • Key: live

scylla_gossip_unreachable¶

How many unreachable nodes the current node sees

  • Type: gauge

  • Component: gossip

  • Key: unreachable

Logalloc¶

scylla_lsa_total_space_bytes¶

Holds a current size of allocated memory in bytes.

  • Type: gauge

  • Component: lsa

  • Key: total_space_bytes

scylla_lsa_used_space_bytes¶

Holds a current amount of used memory in bytes.

  • Type: gauge

  • Component: lsa

  • Key: used_space_bytes

scylla_lsa_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

scylla_lsa_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

scylla_lsa_large_objects_total_space_bytes¶

Holds a current size of allocated non-LSA memory.

  • Type: gauge

  • Component: lsa

  • Key: large_objects_total_space_bytes

scylla_lsa_non_lsa_used_space_bytes¶

Holds a current amount of used non-LSA memory.

  • Type: gauge

  • Component: lsa

  • Key: non_lsa_used_space_bytes

scylla_lsa_free_space¶

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

  • Type: gauge

  • Component: lsa

  • Key: free_space

scylla_lsa_occupancy¶

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

  • Type: gauge

  • Component: lsa

  • Key: occupancy

scylla_lsa_segments_compacted¶

Counts a number of compacted segments.

  • Type: counter

  • Component: lsa

  • Key: segments_compacted

scylla_lsa_memory_compacted¶

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

  • Type: counter

  • Component: lsa

  • Key: memory_compacted

scylla_lsa_memory_allocated¶

Counts number of bytes which were requested from LSA.

  • Type: counter

  • Component: lsa

  • Key: memory_allocated

scylla_lsa_memory_evicted¶

Counts number of bytes which were evicted.

  • Type: counter

  • Component: lsa

  • Key: memory_evicted

scylla_lsa_memory_freed¶

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

  • Type: counter

  • Component: lsa

  • Key: memory_freed

Main¶

scylla_scylladb_current_version¶

Current ScyllaDB version.

  • Type: gauge

  • Component: scylladb

  • Key: current_version

Manager¶

scylla_group_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

scylla_group_name_written¶

Number of successfully written hints.

  • Type: counter

  • Component: group_name

  • Key: written

scylla_group_name_errors¶

Number of errors during hints writes.

  • Type: counter

  • Component: group_name

  • Key: errors

scylla_group_name_dropped¶

Number of dropped hints.

  • Type: counter

  • Component: group_name

  • Key: dropped

scylla_group_name_sent¶

Number of sent hints.

  • Type: counter

  • Component: group_name

  • Key: sent

scylla_group_name_discarded¶

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

  • Type: counter

  • Component: group_name

  • Key: discarded

scylla_group_name_send_errors¶

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

  • Type: counter

  • Component: group_name

  • Key: send_errors

scylla_group_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

scylla_group_name_pending_drains¶

Number of tasks waiting in the queue for draining hints

  • Type: gauge

  • Component: group_name

  • Key: pending_drains

scylla_group_name_pending_sends¶

Number of tasks waiting in the queue for sending a hint

  • Type: gauge

  • Component: group_name

  • Key: pending_sends

Query processor¶

scylla_cql_reads¶

Counts the total number of CQL SELECT requests.

  • Type: counter

  • Component: cql

  • Key: reads

scylla_cql_inserts¶

Counts the total number of CQL INSERT requests with/without conditions.

  • Type: counter

  • Component: cql

  • Key: inserts

scylla_cql_updates¶

Counts the total number of CQL UPDATE requests with/without conditions.

  • Type: counter

  • Component: cql

  • Key: updates

scylla_cql_deletes¶

Counts the total number of CQL DELETE requests with/without conditions.

  • Type: counter

  • Component: cql

  • Key: deletes

scylla_cql_reads_per_ks¶

Counts the number of CQL SELECT requests executed on particular keyspaces. Label `who’ indicates where the reqs come from (clients or DB internals)

  • Type: counter

  • Component: cql

  • Key: reads_per_ks

scylla_cql_inserts_per_ks¶

Counts the number of CQL INSERT requests executed on particular keyspaces. Label `who’ indicates where the reqs come from (clients or DB internals).

  • Type: counter

  • Component: cql

  • Key: inserts_per_ks

scylla_cql_updates_per_ks¶

Counts the number of CQL UPDATE requests executed on particular keyspaces. Label `who’ indicates where the reqs come from (clients or DB internals)

  • Type: counter

  • Component: cql

  • Key: updates_per_ks

scylla_cql_deletes_per_ks¶

Counts the number of CQL DELETE requests executed on particular keyspaces. Label `who’ indicates where the reqs come from (clients or DB internals)

  • Type: counter

  • Component: cql

  • Key: deletes_per_ks

scylla_cql_batches¶

Counts the total number of CQL BATCH requests without conditions.

  • Type: counter

  • Component: cql

  • Key: batches

scylla_cql_statements_in_batches¶

Counts the total number of sub-statements in CQL BATCH requests without conditions.

  • Type: counter

  • Component: cql

  • Key: statements_in_batches

scylla_cql_batches_pure_logged¶

Counts the total number of LOGGED batches that were executed as LOGGED batches.

  • Type: counter

  • Component: cql

  • Key: batches_pure_logged

scylla_cql_batches_pure_unlogged¶

Counts the total number of UNLOGGED batches that were executed as UNLOGGED batches.

  • Type: counter

  • Component: cql

  • Key: batches_pure_unlogged

scylla_cql_batches_unlogged_from_logged¶

Counts the total number of LOGGED batches that were executed as UNLOGGED batches.

  • Type: counter

  • Component: cql

  • Key: batches_unlogged_from_logged

scylla_cql_rows_read¶

Counts the total number of rows read during CQL requests.

  • Type: counter

  • Component: cql

  • Key: rows_read

scylla_cql_prepared_cache_evictions¶

Counts the number of prepared statements cache entries evictions.

  • Type: counter

  • Component: cql

  • Key: prepared_cache_evictions

scylla_cql_unprivileged_entries_evictions_on_size¶

Counts a number of evictions of prepared statements from the prepared statements cache after they have been used only once. An increasing counter suggests the user may be preparing a different statement for each request instead of reusing the same prepared statement with parameters.

  • Type: counter

  • Component: cql

  • Key: unprivileged_entries_evictions_on_size

scylla_cql_prepared_cache_size¶

A number of entries in the prepared statements cache.

  • Type: gauge

  • Component: cql

  • Key: prepared_cache_size

scylla_cql_prepared_cache_memory_footprint¶

Size (in bytes) of the prepared statements cache.

  • Type: gauge

  • Component: cql

  • Key: prepared_cache_memory_footprint

scylla_cql_secondary_index_creates¶

Counts the total number of CQL CREATE INDEX requests.

  • Type: counter

  • Component: cql

  • Key: secondary_index_creates

scylla_cql_secondary_index_drops¶

Counts the total number of CQL DROP INDEX requests.

  • Type: counter

  • Component: cql

  • Key: secondary_index_drops

scylla_cql_secondary_index_reads¶

Counts the total number of CQL read requests performed using secondary indexes.

  • Type: counter

  • Component: cql

  • Key: secondary_index_reads

scylla_cql_secondary_index_rows_read¶

Counts the total number of rows read during CQL requests performed using secondary indexes.

  • Type: counter

  • Component: cql

  • Key: secondary_index_rows_read

scylla_cql_filtered_read_requests¶

Counts the total number of CQL read requests that required ALLOW FILTERING. See filtered_rows_read_total to compare how many rows needed to be filtered.

  • Type: counter

  • Component: cql

  • Key: filtered_read_requests

scylla_cql_filtered_rows_read_total¶

Counts the total number of rows read during CQL requests that required ALLOW FILTERING. See filtered_rows_matched_total and filtered_rows_dropped_total for information how accurate filtering queries are.

  • Type: counter

  • Component: cql

  • Key: filtered_rows_read_total

scylla_cql_filtered_rows_matched_total¶

Counts the number of rows read during CQL requests that required ALLOW FILTERING and accepted by the filter. Number similar to filtered_rows_read_total indicates that filtering is accurate.

  • Type: counter

  • Component: cql

  • Key: filtered_rows_matched_total

scylla_cql_filtered_rows_dropped_total¶

Counts the number of rows read during CQL requests that required ALLOW FILTERING and dropped by the filter. Number similar to filtered_rows_read_total indicates that filtering is not accurate and might cause performance degradation.

  • Type: counter

  • Component: cql

  • Key: filtered_rows_dropped_total

scylla_cql_select_bypass_caches¶

Counts the number of SELECT query executions with BYPASS CACHE option.

  • Type: counter

  • Component: cql

  • Key: select_bypass_caches

scylla_cql_select_allow_filtering¶

Counts the number of SELECT query executions with ALLOW FILTERING option.

  • Type: counter

  • Component: cql

  • Key: select_allow_filtering

scylla_cql_select_partition_range_scan¶

Counts the number of SELECT query executions requiring partition range scan.

  • Type: counter

  • Component: cql

  • Key: select_partition_range_scan

scylla_cql_select_partition_range_scan_no_bypass_cache¶

Counts the number of SELECT query executions requiring partition range scan without BYPASS CACHE option.

  • Type: counter

  • Component: cql

  • Key: select_partition_range_scan_no_bypass_cache

scylla_cql_select_parallelized¶

Counts the number of parallelized aggregation SELECT query executions.

  • Type: counter

  • Component: cql

  • Key: select_parallelized

scylla_cql_authorized_prepared_statements_cache_evictions¶

Counts the number of authenticated prepared statements cache entries evictions.

  • Type: counter

  • Component: cql

  • Key: authorized_prepared_statements_cache_evictions

scylla_cql_authorized_prepared_statements_privileged_entries_evictions_on_size¶

Counts a number of evictions of prepared statements from the authorized prepared statements cache after they have been used more than once.

  • Type: counter

  • Component: cql

  • Key: authorized_prepared_statements_privileged_entries_evictions_on_size

scylla_cql_authorized_prepared_statements_unprivileged_entries_evictions_on_size¶

Counts a number of evictions of prepared statements from the authorized prepared statements cache after they have been used only once. An increasing counter suggests the user may be preparing a different statement for each request instead of reusing the same prepared statement with parameters.

  • Type: counter

  • Component: cql

  • Key: authorized_prepared_statements_unprivileged_entries_evictions_on_size

scylla_cql_authorized_prepared_statements_cache_size¶

Number of entries in the authenticated prepared statements cache.

  • Type: gauge

  • Component: cql

  • Key: authorized_prepared_statements_cache_size

scylla_cql_user_prepared_auth_cache_footprint¶

Size (in bytes) of the authenticated prepared statements cache.

  • Type: gauge

  • Component: cql

  • Key: user_prepared_auth_cache_footprint

scylla_cql_reverse_queries¶

Counts the number of CQL SELECT requests with reverse ORDER BY order.

  • Type: counter

  • Component: cql

  • Key: reverse_queries

scylla_cql_unpaged_select_queries¶

Counts the total number of unpaged CQL SELECT requests.

  • Type: counter

  • Component: cql

  • Key: unpaged_select_queries

scylla_cql_unpaged_select_queries_per_ks¶

Counts the number of unpaged CQL SELECT requests against particular keyspaces.

  • Type: counter

  • Component: cql

  • Key: unpaged_select_queries_per_ks

scylla_cql_minimum_replication_factor_fail_violations¶

Counts the number of minimum_replication_factor_fail_threshold guardrail violations, i.e. attempts to create a keyspace with RF on one of the DCs below the set guardrail.

  • Type: counter

  • Component: cql

  • Key: minimum_replication_factor_fail_violations

scylla_cql_minimum_replication_factor_warn_violations¶

Counts the number of minimum_replication_factor_warn_threshold guardrail violations, i.e. attempts to create a keyspace with RF on one of the DCs below the set guardrail.

  • Type: counter

  • Component: cql

  • Key: minimum_replication_factor_warn_violations

scylla_cql_maximum_replication_factor_warn_violations¶

Counts the number of maximum_replication_factor_warn_threshold guardrail violations, i.e. attempts to create a keyspace with RF on one of the DCs above the set guardrail.

  • Type: counter

  • Component: cql

  • Key: maximum_replication_factor_warn_violations

scylla_cql_maximum_replication_factor_fail_violations¶

Counts the number of maximum_replication_factor_fail_threshold guardrail violations, i.e. attempts to create a keyspace with RF on one of the DCs above the set guardrail.

  • Type: counter

  • Component: cql

  • Key: maximum_replication_factor_fail_violations

scylla_cql_replication_strategy_warn_list_violations¶

Counts the number of replication_strategy_warn_list guardrail violations, i.e. attempts to set a discouraged replication strategy in a keyspace via CREATE/ALTER KEYSPACE.

  • Type: counter

  • Component: cql

  • Key: replication_strategy_warn_list_violations

scylla_cql_replication_strategy_fail_list_violations¶

Counts the number of replication_strategy_fail_list guardrail violations, i.e. attempts to set a forbidden replication strategy in a keyspace via CREATE/ALTER KEYSPACE.

  • Type: counter

  • Component: cql

  • Key: replication_strategy_fail_list_violations

Raft group0¶

scylla_raft_group0_status¶

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

  • Type: gauge

  • Component: raft_group0

  • Key: status

Rate limiter¶

scylla_per_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

scylla_per_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

scylla_per_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

scylla_per_partition_rate_limiter_probe_count¶

Number of probes made during lookups.

  • Type: counter

  • Component: per_partition_rate_limiter

  • Key: probe_count

scylla_per_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

Reader concurrency semaphore¶

scylla_database_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

scylla_database_active_reads¶

Holds the number of currently active read operations.

  • Type: gauge

  • Component: database

  • Key: active_reads

scylla_database_reads_memory_consumption¶

Holds the amount of memory consumed by current read operations.

  • Type: gauge

  • Component: database

  • Key: reads_memory_consumption

scylla_database_queued_reads¶

Holds the number of currently queued read operations.

  • Type: gauge

  • Component: database

  • Key: queued_reads

scylla_database_paused_reads¶

The number of currently active reads that are temporarily paused.

  • Type: gauge

  • Component: database

  • Key: paused_reads

scylla_database_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

scylla_database_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

scylla_database_disk_reads¶

Holds the number of currently active disk read operations.

  • Type: gauge

  • Component: database

  • Key: disk_reads

scylla_database_sstables_read¶

Holds the number of currently read sstables.

  • Type: gauge

  • Component: database

  • Key: sstables_read

scylla_database_total_reads¶

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

  • Type: counter

  • Component: database

  • Key: total_reads

scylla_database_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

Repair¶

scylla_node_ops_finished_percentage¶

Finished percentage of node operation on this shard

  • Type: gauge

  • Component: node_ops

  • Key: finished_percentage

Row cache¶

scylla_cache_bytes_used¶

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

  • Type: gauge

  • Component: cache

  • Key: bytes_used

scylla_cache_bytes_total¶

total size of memory for the cache

  • Type: gauge

  • Component: cache

  • Key: bytes_total

scylla_cache_partition_hits¶

number of partitions needed by reads and found in cache

  • Type: counter

  • Component: cache

  • Key: partition_hits

scylla_cache_partition_misses¶

number of partitions needed by reads and missing in cache

  • Type: counter

  • Component: cache

  • Key: partition_misses

scylla_cache_partition_insertions¶

total number of partitions added to cache

  • Type: counter

  • Component: cache

  • Key: partition_insertions

scylla_cache_row_hits¶

total number of rows needed by reads and found in cache

  • Type: counter

  • Component: cache

  • Key: row_hits

scylla_cache_dummy_row_hits¶

total number of dummy rows touched by reads in cache

  • Type: counter

  • Component: cache

  • Key: dummy_row_hits

scylla_cache_row_misses¶

total number of rows needed by reads and missing in cache

  • Type: counter

  • Component: cache

  • Key: row_misses

scylla_cache_row_insertions¶

total number of rows added to cache

  • Type: counter

  • Component: cache

  • Key: row_insertions

scylla_cache_row_evictions¶

total number of rows evicted from cache

  • Type: counter

  • Component: cache

  • Key: row_evictions

scylla_cache_row_removals¶

total number of invalidated rows

  • Type: counter

  • Component: cache

  • Key: row_removals

scylla_cache_rows_dropped_by_tombstones¶

Number of rows dropped in cache by a tombstone write

  • Type: counter

  • Component: cache

  • Key: rows_dropped_by_tombstones

scylla_cache_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

scylla_cache_static_row_insertions¶

total number of static rows added to cache

  • Type: counter

  • Component: cache

  • Key: static_row_insertions

scylla_cache_concurrent_misses_same_key¶

total number of operation with misses same key

  • Type: counter

  • Component: cache

  • Key: concurrent_misses_same_key

scylla_cache_partition_merges¶

total number of partitions merged

  • Type: counter

  • Component: cache

  • Key: partition_merges

scylla_cache_partition_evictions¶

total number of evicted partitions

  • Type: counter

  • Component: cache

  • Key: partition_evictions

scylla_cache_partition_removals¶

total number of invalidated partitions

  • Type: counter

  • Component: cache

  • Key: partition_removals

scylla_cache_mispopulations¶

number of entries not inserted by reads

  • Type: counter

  • Component: cache

  • Key: mispopulations

scylla_cache_partitions¶

total number of cached partitions

  • Type: gauge

  • Component: cache

  • Key: partitions

scylla_cache_rows¶

total number of cached rows

  • Type: gauge

  • Component: cache

  • Key: rows

scylla_cache_reads¶

number of started reads

  • Type: counter

  • Component: cache

  • Key: reads

scylla_cache_reads_with_misses¶

number of reads which had to read from sstables

  • Type: counter

  • Component: cache

  • Key: reads_with_misses

scylla_cache_active_reads¶

number of currently active reads

  • Type: gauge

  • Component: cache

  • Key: active_reads

scylla_cache_sstable_reader_recreations¶

number of times sstable reader was recreated due to memtable flush

  • Type: counter

  • Component: cache

  • Key: sstable_reader_recreations

scylla_cache_sstable_partition_skips¶

number of times sstable reader was fast forwarded across partitions

  • Type: counter

  • Component: cache

  • Key: sstable_partition_skips

scylla_cache_sstable_row_skips¶

number of times sstable reader was fast forwarded within a partition

  • Type: counter

  • Component: cache

  • Key: sstable_row_skips

scylla_cache_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

scylla_cache_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

scylla_cache_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

scylla_cache_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

scylla_cache_range_tombstone_reads¶

total amount of range tombstones processed during read

  • Type: counter

  • Component: cache

  • Key: range_tombstone_reads

scylla_cache_row_tombstone_reads¶

total amount of row tombstones processed during read

  • Type: counter

  • Component: cache

  • Key: row_tombstone_reads

scylla_cache_rows_compacted¶

total amount of attempts to compact expired rows during read

  • Type: counter

  • Component: cache

  • Key: rows_compacted

scylla_cache_rows_compacted_away¶

total amount of compacted and removed rows during read

  • Type: counter

  • Component: cache

  • Key: rows_compacted_away

Row level¶

scylla_repair_tx_row_nr¶

Total number of rows sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_row_nr

scylla_repair_rx_row_nr¶

Total number of rows received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_row_nr

scylla_repair_tx_row_bytes¶

Total bytes of rows sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_row_bytes

scylla_repair_rx_row_bytes¶

Total bytes of rows received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_row_bytes

scylla_repair_tx_hashes_nr¶

Total number of row hashes sent on this shard.

  • Type: counter

  • Component: repair

  • Key: tx_hashes_nr

scylla_repair_rx_hashes_nr¶

Total number of row hashes received on this shard.

  • Type: counter

  • Component: repair

  • Key: rx_hashes_nr

scylla_repair_row_from_disk_nr¶

Total number of rows read from disk on this shard.

  • Type: counter

  • Component: repair

  • Key: row_from_disk_nr

scylla_repair_row_from_disk_bytes¶

Total bytes of rows read from disk on this shard.

  • Type: counter

  • Component: repair

  • Key: row_from_disk_bytes

Server¶

scylla_raft_add_entries¶

how many entries were added on this node

  • Type: total_operations

  • Component: raft

  • Key: add_entries

scylla_raft_messages_received¶

how many messages were received

  • Type: total_operations

  • Component: raft

  • Key: messages_received

scylla_raft_messages_sent¶

how many messages were send

  • Type: total_operations

  • Component: raft

  • Key: messages_sent

scylla_raft_waiter_awoken¶

how many waiters got result back

  • Type: total_operations

  • Component: raft

  • Key: waiter_awoken

scylla_raft_waiter_dropped¶

how many waiters did not get result back

  • Type: total_operations

  • Component: raft

  • Key: waiter_dropped

scylla_raft_polls¶

how many time raft state machine was polled

  • Type: total_operations

  • Component: raft

  • Key: polls

scylla_raft_store_term_and_vote¶

how many times term and vote were persisted

  • Type: total_operations

  • Component: raft

  • Key: store_term_and_vote

scylla_raft_store_snapshot¶

how many snapshot were persisted

  • Type: total_operations

  • Component: raft

  • Key: store_snapshot

scylla_raft_sm_load_snapshot¶

how many times user state machine was reloaded with a snapshot

  • Type: total_operations

  • Component: raft

  • Key: sm_load_snapshot

scylla_raft_truncate_persisted_log¶

how many times log was truncated on storage

  • Type: total_operations

  • Component: raft

  • Key: truncate_persisted_log

scylla_raft_persisted_log_entries¶

how many log entries were persisted

  • Type: total_operations

  • Component: raft

  • Key: persisted_log_entries

scylla_raft_queue_entries_for_apply¶

how many log entries were queued to be applied

  • Type: total_operations

  • Component: raft

  • Key: queue_entries_for_apply

scylla_raft_applied_entries¶

how many log entries were applied

  • Type: total_operations

  • Component: raft

  • Key: applied_entries

scylla_raft_snapshots_taken¶

how many time the user’s state machine was snapshotted

  • Type: total_operations

  • Component: raft

  • Key: snapshots_taken

scylla_raft_in_memory_log_size¶

size of in-memory part of the log

  • Type: gauge

  • Component: raft

  • Key: in_memory_log_size

scylla_raft_log_memory_usage¶

memory usage of in-memory part of the log in bytes

  • Type: gauge

  • Component: raft

  • Key: log_memory_usage

Sstables¶

scylla_sstables_index_page_cache_hits¶

Index page cache requests which were served from cache

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_hits

scylla_sstables_index_page_cache_misses¶

Index page cache requests which had to perform I/O

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_misses

scylla_sstables_index_page_cache_evictions¶

Total number of index page cache pages which have been evicted

  • Type: counter

  • Component: sstables

  • Key: index_page_cache_evictions

scylla_sstables_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

scylla_sstables_index_page_cache_bytes¶

Total number of bytes cached in the index page cache

  • Type: gauge

  • Component: sstables

  • Key: index_page_cache_bytes

scylla_sstables_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

scylla_sstables_index_page_hits¶

Index page requests which could be satisfied without waiting

  • Type: counter

  • Component: sstables

  • Key: index_page_hits

scylla_sstables_index_page_misses¶

Index page requests which initiated a read from disk

  • Type: counter

  • Component: sstables

  • Key: index_page_misses

scylla_sstables_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

scylla_sstables_index_page_evictions¶

Index pages which got evicted from memory

  • Type: counter

  • Component: sstables

  • Key: index_page_evictions

scylla_sstables_index_page_populations¶

Index pages which got populated into memory

  • Type: counter

  • Component: sstables

  • Key: index_page_populations

scylla_sstables_index_page_used_bytes¶

Amount of bytes used by index pages in memory

  • Type: gauge

  • Component: sstables

  • Key: index_page_used_bytes

scylla_sstables_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

scylla_sstables_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

scylla_sstables_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

scylla_sstables_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

scylla_sstables_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

scylla_sstables_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

scylla_sstables_pi_cache_populations¶

Number of promoted index blocks which got inserted

  • Type: counter

  • Component: sstables

  • Key: pi_cache_populations

scylla_sstables_pi_cache_evictions¶

Number of promoted index blocks which got evicted

  • Type: counter

  • Component: sstables

  • Key: pi_cache_evictions

scylla_sstables_pi_cache_bytes¶

Number of bytes currently used by cached promoted index blocks

  • Type: gauge

  • Component: sstables

  • Key: pi_cache_bytes

scylla_sstables_pi_cache_block_count¶

Number of promoted index blocks currently cached

  • Type: gauge

  • Component: sstables

  • Key: pi_cache_block_count

scylla_sstables_partition_writes¶

Number of partitions written

  • Type: counter

  • Component: sstables

  • Key: partition_writes

scylla_sstables_static_row_writes¶

Number of static rows written

  • Type: counter

  • Component: sstables

  • Key: static_row_writes

scylla_sstables_row_writes¶

Number of clustering rows written

  • Type: counter

  • Component: sstables

  • Key: row_writes

scylla_sstables_cell_writes¶

Number of cells written

  • Type: counter

  • Component: sstables

  • Key: cell_writes

scylla_sstables_tombstone_writes¶

Number of tombstones written

  • Type: counter

  • Component: sstables

  • Key: tombstone_writes

scylla_sstables_range_tombstone_writes¶

Number of range tombstones written

  • Type: counter

  • Component: sstables

  • Key: range_tombstone_writes

scylla_sstables_pi_auto_scale_events¶

Number of promoted index auto-scaling events

  • Type: counter

  • Component: sstables

  • Key: pi_auto_scale_events

scylla_sstables_range_tombstone_reads¶

Number of range tombstones read

  • Type: counter

  • Component: sstables

  • Key: range_tombstone_reads

scylla_sstables_row_tombstone_reads¶

Number of row tombstones read

  • Type: counter

  • Component: sstables

  • Key: row_tombstone_reads

scylla_sstables_cell_tombstone_writes¶

Number of cell tombstones written

  • Type: counter

  • Component: sstables

  • Key: cell_tombstone_writes

scylla_sstables_single_partition_reads¶

Number of single partition flat mutation reads

  • Type: counter

  • Component: sstables

  • Key: single_partition_reads

scylla_sstables_range_partition_reads¶

Number of partition range flat mutation reads

  • Type: counter

  • Component: sstables

  • Key: range_partition_reads

scylla_sstables_partition_reads¶

Number of partitions read

  • Type: counter

  • Component: sstables

  • Key: partition_reads

scylla_sstables_partition_seeks¶

Number of partitions seeked

  • Type: counter

  • Component: sstables

  • Key: partition_seeks

scylla_sstables_row_reads¶

Number of rows read

  • Type: counter

  • Component: sstables

  • Key: row_reads

scylla_sstables_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

scylla_sstables_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

scylla_sstables_total_open_for_reading¶

Counter of sstables open for reading

  • Type: counter

  • Component: sstables

  • Key: total_open_for_reading

scylla_sstables_total_open_for_writing¶

Counter of sstables open for writing

  • Type: counter

  • Component: sstables

  • Key: total_open_for_writing

scylla_sstables_currently_open_for_reading¶

Number of sstables currently open for reading

  • Type: gauge

  • Component: sstables

  • Key: currently_open_for_reading

scylla_sstables_currently_open_for_writing¶

Number of sstables currently open for writing

  • Type: gauge

  • Component: sstables

  • Key: currently_open_for_writing

scylla_sstables_total_deleted¶

Counter of deleted sstables

  • Type: counter

  • Component: sstables

  • Key: total_deleted

scylla_sstables_bloom_filter_memory_size¶

Bloom filter memory usage in bytes.

  • Type: gauge

  • Component: sstables

  • Key: bloom_filter_memory_size

Stats¶

scylla_alternator_operation¶

number of operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: operation

scylla_alternator_op_latency¶

Latency histogram of an operation via Alternator API

  • Type: histogram

  • Component: alternator

  • Key: op_latency

scylla_alternator_op_latency_summary¶

Latency summary of an operation via Alternator API

  • Type: summary

  • Component: alternator

  • Key: op_latency_summary

scylla_alternator_unsupported_operations¶

number of unsupported operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: unsupported_operations

scylla_alternator_total_operations¶

number of total operations via Alternator API

  • Type: total_operations

  • Component: alternator

  • Key: total_operations

scylla_alternator_reads_before_write¶

number of performed read-before-write operations

  • Type: total_operations

  • Component: alternator

  • Key: reads_before_write

scylla_alternator_write_using_lwt¶

number of writes that used LWT

  • Type: total_operations

  • Component: alternator

  • Key: write_using_lwt

scylla_alternator_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

scylla_alternator_requests_blocked_memory¶

Counts a number of requests blocked due to memory pressure.

  • Type: total_operations

  • Component: alternator

  • Key: requests_blocked_memory

scylla_alternator_requests_shed¶

Counts a number of requests shed due to overload.

  • Type: total_operations

  • Component: alternator

  • Key: requests_shed

scylla_alternator_filtered_rows_read_total¶

number of rows read during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_read_total

scylla_alternator_filtered_rows_matched_total¶

number of rows read and matched during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_matched_total

scylla_alternator_filtered_rows_dropped_total¶

number of rows read and dropped during filtering operations

  • Type: total_operations

  • Component: alternator

  • Key: filtered_rows_dropped_total

Storage service¶

scylla_node_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

Stream manager¶

scylla_streaming_total_incoming_bytes¶

Total number of bytes received on this shard.

  • Type: counter

  • Component: streaming

  • Key: total_incoming_bytes

scylla_streaming_total_outgoing_bytes¶

Total number of bytes sent on this shard.

  • Type: counter

  • Component: streaming

  • Key: total_outgoing_bytes

scylla_streaming_finished_percentage¶

Finished percentage of node operation on this shard

  • Type: gauge

  • Component: streaming

  • Key: finished_percentage

Table¶

scylla_column_family_memtable_switch¶

Number of times flush has resulted in the memtable being switched out

  • Type: counter

  • Component: column_family

  • Key: memtable_switch

scylla_column_family_memtable_partition_writes¶

Number of write operations performed on partitions in memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_partition_writes

scylla_column_family_memtable_partition_hits¶

Number of times a write operation was issued on an existing partition in memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_partition_hits

scylla_column_family_memtable_row_writes¶

Number of row writes performed in memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_row_writes

scylla_column_family_memtable_row_hits¶

Number of rows overwritten by write operations in memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_row_hits

scylla_column_family_memtable_rows_dropped_by_tombstones¶

Number of rows dropped in memtables by a tombstone write

  • Type: counter

  • Component: column_family

  • Key: memtable_rows_dropped_by_tombstones

scylla_column_family_memtable_rows_compacted_with_tombstones¶

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

  • Type: counter

  • Component: column_family

  • Key: memtable_rows_compacted_with_tombstones

scylla_column_family_memtable_range_tombstone_reads¶

Number of range tombstones read from memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_range_tombstone_reads

scylla_column_family_memtable_row_tombstone_reads¶

Number of row tombstones read from memtables

  • Type: counter

  • Component: column_family

  • Key: memtable_row_tombstone_reads

scylla_column_family_pending_tasks¶

Estimated number of tasks pending for this column family

  • Type: gauge

  • Component: column_family

  • Key: pending_tasks

scylla_column_family_live_disk_space¶

Live disk space used

  • Type: gauge

  • Component: column_family

  • Key: live_disk_space

scylla_column_family_total_disk_space¶

Total disk space used

  • Type: gauge

  • Component: column_family

  • Key: total_disk_space

scylla_column_family_live_sstable¶

Live sstable count

  • Type: gauge

  • Component: column_family

  • Key: live_sstable

scylla_column_family_pending_compaction¶

Estimated number of compactions pending for this column family

  • Type: gauge

  • Component: column_family

  • Key: pending_compaction

scylla_column_family_pending_sstable_deletions¶

Number of tasks waiting to delete sstables from a table

  • Type: gauge

  • Component: column_family

  • Key: pending_sstable_deletions

Tablet allocator¶

scylla_group_name_calls¶

number of calls to the load balancer

  • Type: counter

  • Component: group_name

  • Key: calls

scylla_group_name_migrations_produced¶

number of migrations produced by the load balancer

  • Type: counter

  • Component: group_name

  • Key: migrations_produced

scylla_group_name_migrations_skipped¶

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

  • Type: counter

  • Component: group_name

  • Key: migrations_skipped

scylla_group_name_load¶

node load during last load balancing

  • Type: gauge

  • Component: group_name

  • Key: load

scylla_group_name_resizes_emitted¶

number of resizes produced by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_emitted

scylla_group_name_resizes_revoked¶

number of resizes revoked by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_revoked

scylla_group_name_resizes_finalized¶

number of resizes finalized by the load balancer

  • Type: counter

  • Component: group_name

  • Key: resizes_finalized

Trace keyspace helper¶

scylla_tracing_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

scylla_tracing_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

Ttl¶

scylla_expiration_scan_passes¶

number of passes over the database

  • Type: total_operations

  • Component: expiration

  • Key: scan_passes

scylla_expiration_scan_table¶

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

  • Type: total_operations

  • Component: expiration

  • Key: scan_table

scylla_expiration_items_deleted¶

number of items deleted after expiration

  • Type: total_operations

  • Component: expiration

  • Key: items_deleted

scylla_expiration_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

View¶

scylla_column_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

scylla_column_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

scylla_column_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

scylla_column_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

scylla_column_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

scylla_view_builder_pending_bookkeeping_ops¶

Number of tasks waiting to perform bookkeeping operations

  • Type: gauge

  • Component: view_builder

  • Key: pending_bookkeeping_ops

scylla_view_builder_steps_performed¶

Number of performed build steps.

  • Type: counter

  • Component: view_builder

  • Key: steps_performed

scylla_view_builder_steps_failed¶

Number of failed build steps.

  • Type: counter

  • Component: view_builder

  • Key: steps_failed

scylla_view_builder_builds_in_progress¶

Number of currently active view builds.

  • Type: gauge

  • Component: view_builder

  • Key: builds_in_progress

View update generator¶

scylla_view_update_generator_pending_registrations¶

Number of tasks waiting to register staging sstables

  • Type: gauge

  • Component: view_update_generator

  • Key: pending_registrations

scylla_view_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

scylla_view_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

scylla_view_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

Wasm instance cache¶

scylla_user_functions_cache_hits¶

The number of user defined function cache hits

  • Type: counter

  • Component: user_functions

  • Key: cache_hits

scylla_user_functions_cache_misses¶

The number of user defined functions loaded

  • Type: counter

  • Component: user_functions

  • Key: cache_misses

scylla_user_functions_cache_blocks¶

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

  • Type: counter

  • Component: user_functions

  • Key: cache_blocks

scylla_user_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

scylla_user_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

Was this page helpful?

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

On this page

  • Metrics (BETA)
    • Batchlog manager
    • Client
    • Compaction manager
    • Forward service
    • Gossiper
    • Logalloc
    • Main
    • Manager
    • Query processor
    • Raft group0
    • Rate limiter
    • Reader concurrency semaphore
    • Repair
    • Row cache
    • Row level
    • Server
    • Sstables
    • Stats
    • Storage service
    • Stream manager
    • Table
    • Tablet allocator
    • Trace keyspace helper
    • Ttl
    • View
    • View update generator
    • 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 17 Dec 2025.
Powered by Sphinx 8.1.3 & ScyllaDB Theme 1.8.10
Ask AI