List of ScyllaDB metrics
Documentation of all Prometheus metrics exported by ScyllaDB generated from http://scylla-url:9180/metrics
Metric | Type | Description | |
---|---|---|---|
1 | scylla_alien_receive_batch_queue_length | gauge | Current receive batch queue length |
2 | scylla_alien_total_received_messages | counter | Total number of received messages |
3 | scylla_alien_total_sent_messages | counter | Total number of sent messages |
4 | scylla_batchlog_manager_total_write_replay_attempts | counter | Counts write operations issued in a batchlog replay flow. The high value of this metric indicates that we have a long batch replay list. |
5 | scylla_cache_active_reads | gauge | number of currently active reads |
6 | scylla_cache_bytes_total | gauge | total size of memory for the cache |
7 | scylla_cache_bytes_used | gauge | current bytes used by the cache out of the total size of memory |
8 | scylla_cache_concurrent_misses_same_key | counter | total number of operation with misses same key |
9 | scylla_cache_dummy_row_hits | counter | total number of dummy rows touched by reads in cache |
10 | scylla_cache_mispopulations | counter | number of entries not inserted by reads |
11 | scylla_cache_partition_evictions | counter | total number of evicted partitions |
12 | scylla_cache_partition_hits | counter | number of partitions needed by reads and found in cache |
13 | scylla_cache_partition_insertions | counter | total number of partitions added to cache |
14 | scylla_cache_partition_merges | counter | total number of partitions merged |
15 | scylla_cache_partition_misses | counter | number of partitions needed by reads and missing in cache |
16 | scylla_cache_partition_removals | counter | total number of invalidated partitions |
17 | scylla_cache_partitions | gauge | total number of cached partitions |
18 | scylla_cache_pinned_dirty_memory_overload | counter | 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 |
19 | scylla_cache_range_tombstone_reads | counter | total amount of range tombstones processed during read |
20 | scylla_cache_reads | counter | number of started reads |
21 | scylla_cache_reads_with_misses | counter | number of reads which had to read from sstables |
22 | scylla_cache_row_evictions | counter | total number of rows evicted from cache |
23 | scylla_cache_row_hits | counter | total number of rows needed by reads and found in cache |
24 | scylla_cache_row_insertions | counter | total number of rows added to cache |
25 | scylla_cache_row_misses | counter | total number of rows needed by reads and missing in cache |
26 | scylla_cache_row_removals | counter | total number of invalidated rows |
27 | scylla_cache_row_tombstone_reads | counter | total amount of row tombstones processed during read |
28 | scylla_cache_rows | gauge | total number of cached rows |
29 | scylla_cache_rows_compacted_with_tombstones | counter | Number of rows scanned during write of a tombstone for the purpose of compaction in cache |
30 | scylla_cache_rows_dropped_by_tombstones | counter | Number of rows dropped in cache by a tombstone write |
31 | scylla_cache_rows_dropped_from_memtable | counter | total number of rows in memtables which were dropped during cache update on memtable flush |
32 | scylla_cache_rows_merged_from_memtable | counter | total number of rows in memtables which were merged with existing rows during cache update on memtable flush |
33 | scylla_cache_rows_processed_from_memtable | counter | total number of rows in memtables which were processed during cache update on memtable flush |
34 | scylla_cache_sstable_partition_skips | counter | number of times sstable reader was fast forwarded across partitions |
35 | scylla_cache_sstable_reader_recreations | counter | number of times sstable reader was recreated due to memtable flush |
36 | scylla_cache_sstable_row_skips | counter | number of times sstable reader was fast forwarded within a partition |
37 | scylla_cache_static_row_insertions | counter | total number of static rows added to cache |
38 | scylla_cdc_operations_failed | counter | number of failed CDC operations |
39 | scylla_cdc_operations_on_clustering_row_performed_failed | counter | number of failed CDC operations that processed a clustering_row |
40 | scylla_cdc_operations_on_clustering_row_performed_total | counter | number of total CDC operations that processed a clustering_row |
41 | scylla_cdc_operations_on_list_performed_failed | counter | number of failed CDC operations that processed a list |
42 | scylla_cdc_operations_on_list_performed_total | counter | number of total CDC operations that processed a list |
43 | scylla_cdc_operations_on_map_performed_failed | counter | number of failed CDC operations that processed a map |
44 | scylla_cdc_operations_on_map_performed_total | counter | number of total CDC operations that processed a map |
45 | scylla_cdc_operations_on_partition_delete_performed_failed | counter | number of failed CDC operations that processed a partition_delete |
46 | scylla_cdc_operations_on_partition_delete_performed_total | counter | number of total CDC operations that processed a partition_delete |
47 | scylla_cdc_operations_on_range_tombstone_performed_failed | counter | number of failed CDC operations that processed a range_tombstone |
48 | scylla_cdc_operations_on_range_tombstone_performed_total | counter | number of total CDC operations that processed a range_tombstone |
49 | scylla_cdc_operations_on_row_delete_performed_failed | counter | number of failed CDC operations that processed a row_delete |
50 | scylla_cdc_operations_on_row_delete_performed_total | counter | number of total CDC operations that processed a row_delete |
51 | scylla_cdc_operations_on_set_performed_failed | counter | number of failed CDC operations that processed a set |
52 | scylla_cdc_operations_on_set_performed_total | counter | number of total CDC operations that processed a set |
53 | scylla_cdc_operations_on_static_row_performed_failed | counter | number of failed CDC operations that processed a static_row |
54 | scylla_cdc_operations_on_static_row_performed_total | counter | number of total CDC operations that processed a static_row |
55 | scylla_cdc_operations_on_udt_performed_failed | counter | number of failed CDC operations that processed a udt |
56 | scylla_cdc_operations_on_udt_performed_total | counter | number of total CDC operations that processed a udt |
57 | scylla_cdc_operations_total | counter | number of total CDC operations |
58 | scylla_cdc_operations_with_postimage_failed | counter | number of failed operations that included postimage |
59 | scylla_cdc_operations_with_postimage_total | counter | number of total operations that included postimage |
60 | scylla_cdc_operations_with_preimage_failed | counter | number of failed operations that included preimage |
61 | scylla_cdc_operations_with_preimage_total | counter | number of total operations that included preimage |
62 | scylla_cdc_preimage_selects_failed | counter | number of failed preimage queries performed |
63 | scylla_cdc_preimage_selects_total | counter | number of total preimage queries performed |
64 | scylla_column_family_cache_hit_rate | gauge | Cache hit rate |
65 | scylla_column_family_cas_commit_latency | histogram | CAS learn round latency histogram |
66 | scylla_column_family_cas_commit_latency_summary | summary | CAS learn round latency summary |
67 | scylla_column_family_cas_prepare_latency | histogram | CAS prepare round latency histogram |
68 | scylla_column_family_cas_prepare_latency_summary | summary | CAS prepare round latency summary |
69 | scylla_column_family_cas_propose_latency | histogram | CAS accept round latency histogram |
70 | scylla_column_family_cas_propose_latency_summary | summary | CAS accept round latency summary |
71 | scylla_column_family_live_disk_space | gauge | Live disk space used |
72 | scylla_column_family_live_sstable | gauge | Live sstable count |
73 | scylla_column_family_memtable_partition_hits | counter | Number of times a write operation was issued on an existing partition in memtables |
74 | scylla_column_family_memtable_partition_writes | counter | Number of write operations performed on partitions in memtables |
75 | scylla_column_family_memtable_row_hits | counter | Number of rows overwritten by write operations in memtables |
76 | scylla_column_family_memtable_row_tombstone_reads | counter | Number of row tombstones read from memtables |
77 | scylla_column_family_memtable_row_writes | counter | Number of row writes performed in memtables |
78 | scylla_column_family_memtable_rows_compacted_with_tombstones | counter | Number of rows scanned during write of a tombstone for the purpose of compaction in memtables |
79 | scylla_column_family_memtable_rows_dropped_by_tombstones | counter | Number of rows dropped in memtables by a tombstone write |
80 | scylla_column_family_memtable_switch | counter | Number of times flush has resulted in the memtable being switched out |
81 | scylla_column_family_pending_compaction | gauge | Estimated number of compactions pending for this column family |
82 | scylla_column_family_pending_sstable_deletions | gauge | Number of tasks waiting to delete sstables from a table |
83 | scylla_column_family_pending_tasks | gauge | Estimated number of tasks pending for this column family |
84 | scylla_column_family_read_latency | histogram | Read latency histogram |
85 | scylla_column_family_read_latency_summary | summary | Read latency summary |
86 | scylla_column_family_row_lock_exclusive_partition_acquisitions | counter | Row lock acquisitions for exclusive_partition lock |
87 | scylla_column_family_row_lock_exclusive_partition_operations_currently_waiting_for_lock | gauge | Operations currently waiting for exclusive_partition lock |
88 | scylla_column_family_row_lock_exclusive_partition_waiting_time | histogram | Histogram representing time that operations spent on waiting for exclusive_partition lock |
89 | scylla_column_family_row_lock_exclusive_row_acquisitions | counter | Row lock acquisitions for exclusive_row lock |
90 | scylla_column_family_row_lock_exclusive_row_operations_currently_waiting_for_lock | gauge | Operations currently waiting for exclusive_row lock |
91 | scylla_column_family_row_lock_exclusive_row_waiting_time | histogram | Histogram representing time that operations spent on waiting for exclusive_row lock |
92 | scylla_column_family_row_lock_shared_partition_operations_currently_waiting_for_lock | gauge | Operations currently waiting for shared_partition lock |
93 | scylla_column_family_row_lock_shared_row_operations_currently_waiting_for_lock | gauge | Operations currently waiting for shared_row lock |
94 | scylla_column_family_total_disk_space | gauge | Total disk space used |
95 | scylla_column_family_view_updates_failed_local | counter | Number of updates (mutations) that failed to be pushed to local view replicas |
96 | scylla_column_family_view_updates_failed_remote | counter | Number of updates (mutations) that failed to be pushed to remote view replicas |
97 | scylla_column_family_view_updates_pending | gauge | Number of updates pushed to view and are still to be completed |
98 | scylla_column_family_view_updates_pushed_local | counter | Number of updates (mutations) pushed to local view replicas |
99 | scylla_column_family_view_updates_pushed_remote | counter | Number of updates (mutations) pushed to remote view replicas |
100 | scylla_column_family_write_latency | histogram | Write latency histogram |
101 | scylla_column_family_write_latency_summary | summary | Write latency summary |
102 | scylla_commitlog_active_allocations | gauge | Current number of active allocations. |
103 | scylla_commitlog_alloc | counter | Counts number of times a new mutation has been added to a segment. Divide bytes_written by this value to get the average number of bytes per mutation written to the disk. |
104 | scylla_commitlog_allocating_segments | gauge | Holds the number of not closed segments that still have some free space. This value should not get too high. |
105 | scylla_commitlog_blocked_on_new_segment | gauge | Number of allocations blocked on acquiring new segment. |
106 | scylla_commitlog_bytes_flush_requested | counter | Counts number of bytes requested to be flushed (persisted). |
107 | scylla_commitlog_bytes_released | counter | Counts number of bytes released from disk. (Deleted/recycled) |
108 | scylla_commitlog_bytes_written | counter | Counts number of bytes written to the disk. Divide this value by "alloc" to get the average number of bytes per mutation written to the disk. |
109 | scylla_commitlog_cycle | counter | Counts number of commitlog write cycles - when the data is written from the internal memory buffer to the disk. |
110 | scylla_commitlog_disk_active_bytes | gauge | Holds size of disk space in bytes used for data so far. A too high value indicates that we have some bottleneck in the writing to sstables path. |
111 | scylla_commitlog_disk_slack_end_bytes | gauge | Holds size of disk space in bytes unused because of segment switching (end slack). A too high value indicates that we do not write enough data to each segment. |
112 | scylla_commitlog_disk_total_bytes | gauge | Holds size of disk space in bytes reserved for data so far. A too high value indicates that we have some bottleneck in the writing to sstables path. |
113 | scylla_commitlog_flush | counter | Counts number of times the flush() method was called for a file. |
114 | scylla_commitlog_flush_limit_exceeded | counter | Counts number of times a flush limit was exceeded. A non-zero value indicates that there are too many pending flush operations (see pending_flushes) and some of them will be blocked till the total amount of pending flush operations drops below 5. |
115 | scylla_commitlog_memory_buffer_bytes | gauge | Holds the total number of bytes in internal memory buffers. |
116 | scylla_commitlog_pending_allocations | gauge | Holds number of currently pending allocations. A non-zero value indicates that we have a bottleneck in the disk write flow. |
117 | scylla_commitlog_pending_flushes | gauge | Holds number of currently pending flushes. See the related flush_limit_exceeded metric. |
118 | scylla_commitlog_requests_blocked_memory | counter | Counts number of requests blocked due to memory pressure. A non-zero value indicates that the commitlog memory quota is not enough to serve the required amount of requests. |
119 | scylla_commitlog_segments | gauge | Holds the current number of segments. |
120 | scylla_commitlog_slack | counter | Counts number of unused bytes written to the disk due to disk segment alignment. |
121 | scylla_commitlog_unused_segments | gauge | Holds the current number of unused segments. A non-zero value indicates that the disk write path became temporary slow. |
122 | scylla_compaction_manager_backlog | gauge | Holds the sum of compaction backlog for all tables in the system. |
123 | scylla_compaction_manager_compactions | gauge | Holds the number of currently active compactions. |
124 | scylla_compaction_manager_completed_compactions | counter | Holds the number of completed compaction tasks. |
125 | scylla_compaction_manager_failed_compactions | counter | Holds the number of failed compaction tasks. |
126 | scylla_compaction_manager_normalized_backlog | gauge | Holds the sum of normalized compaction backlog for all tables in the system. Backlog is normalized by dividing backlog by shard's available memory. |
127 | scylla_compaction_manager_pending_compactions | gauge | Holds the number of compaction tasks waiting for an opportunity to run. |
128 | scylla_compaction_manager_postponed_compactions | gauge | Holds the number of tables with postponed compaction. |
129 | scylla_compaction_manager_validation_errors | counter | Holds the number of encountered validation errors. |
130 | scylla_cql_authorized_prepared_statements_cache_evictions | counter | Counts the number of authenticated prepared statements cache entries evictions. |
131 | scylla_cql_authorized_prepared_statements_cache_size | gauge | Number of entries in the authenticated prepared statements cache. |
132 | scylla_cql_authorized_prepared_statements_unprivileged_entries_evictions_on_size | counter | 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. |
133 | scylla_cql_batches | counter | Counts the total number of CQL BATCH requests without conditions. |
134 | scylla_cql_batches_pure_logged | counter | Counts the total number of LOGGED batches that were executed as LOGGED batches. |
135 | scylla_cql_batches_pure_unlogged | counter | Counts the total number of UNLOGGED batches that were executed as UNLOGGED batches. |
136 | scylla_cql_batches_unlogged_from_logged | counter | Counts the total number of LOGGED batches that were executed as UNLOGGED batches. |
137 | scylla_cql_deletes | counter | Counts the total number of CQL DELETE requests with/without conditions. |
138 | scylla_cql_deletes_per_ks | counter | Counts the number of CQL DELETE requests executed on particular keyspaces. Label `who' indicates where the reqs come from (clients or DB internals) |
139 | scylla_cql_filtered_read_requests | counter | 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. |
140 | scylla_cql_filtered_rows_dropped_total | counter | 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. |
141 | scylla_cql_filtered_rows_matched_total | counter | 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. |
142 | scylla_cql_filtered_rows_read_total | counter | 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. |
143 | scylla_cql_inserts | counter | Counts the total number of CQL INSERT requests with/without conditions. |
144 | scylla_cql_inserts_per_ks | counter | Counts the number of CQL INSERT requests executed on particular keyspaces. Label `who' indicates where the reqs come from (clients or DB internals). |
145 | scylla_cql_prepared_cache_evictions | counter | Counts the number of prepared statements cache entries evictions. |
146 | scylla_cql_prepared_cache_memory_footprint | gauge | Size (in bytes) of the prepared statements cache. |
147 | scylla_cql_prepared_cache_size | gauge | A number of entries in the prepared statements cache. |
148 | scylla_cql_reads | counter | Counts the total number of CQL SELECT requests. |
149 | scylla_cql_reads_per_ks | counter | Counts the number of CQL SELECT requests executed on particular keyspaces. Label `who' indicates where the reqs come from (clients or DB internals) |
150 | scylla_cql_reverse_queries | counter | Counts the number of CQL SELECT requests with reverse ORDER BY order. |
151 | scylla_cql_rows_read | counter | Counts the total number of rows read during CQL requests. |
152 | scylla_cql_secondary_index_creates | counter | Counts the total number of CQL CREATE INDEX requests. |
153 | scylla_cql_secondary_index_drops | counter | Counts the total number of CQL DROP INDEX requests. |
154 | scylla_cql_secondary_index_reads | counter | Counts the total number of CQL read requests performed using secondary indexes. |
155 | scylla_cql_secondary_index_rows_read | counter | Counts the total number of rows read during CQL requests performed using secondary indexes. |
156 | scylla_cql_select_allow_filtering | counter | Counts the number of SELECT query executions with ALLOW FILTERING option. |
157 | scylla_cql_select_bypass_caches | counter | Counts the number of SELECT query executions with BYPASS CACHE option. |
158 | scylla_cql_select_parallelized | counter | Counts the number of parallelized aggregation SELECT query executions. |
159 | scylla_cql_select_partition_range_scan | counter | Counts the number of SELECT query executions requiring partition range scan. |
160 | scylla_cql_select_partition_range_scan_no_bypass_cache | counter | Counts the number of SELECT query executions requiring partition range scan without BYPASS CACHE option. |
161 | scylla_cql_statements_in_batches | counter | Counts the total number of sub-statements in CQL BATCH requests without conditions. |
162 | scylla_cql_unpaged_select_queries | counter | Counts the total number of unpaged CQL SELECT requests. |
163 | scylla_cql_unpaged_select_queries_per_ks | counter | Counts the number of unpaged CQL SELECT requests against particular keyspaces. |
164 | scylla_cql_unprivileged_entries_evictions_on_size | counter | 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. |
165 | scylla_cql_updates | counter | Counts the total number of CQL UPDATE requests with/without conditions. |
166 | scylla_cql_updates_per_ks | counter | Counts the number of CQL UPDATE requests executed on particular keyspaces. Label `who' indicates where the reqs come from (clients or DB internals) |
167 | scylla_cql_user_prepared_auth_cache_footprint | gauge | Size (in bytes) of the authenticated prepared statements cache. |
168 | scylla_database_active_reads | gauge | Holds the number of currently active read operations. |
169 | scylla_database_clustering_filter_count | counter | Counts bloom filter invocations. |
170 | scylla_database_clustering_filter_fast_path_count | counter | Counts number of times bloom filtering short cut to include all sstables when only one full range was specified. |
171 | scylla_database_clustering_filter_sstables_checked | counter | Counts sstables checked after applying the bloom filter. High value indicates that bloom filter is not very efficient. |
172 | scylla_database_clustering_filter_surviving_sstables | counter | Counts sstables that survived the clustering key filtering. High value indicates that bloom filter is not very efficient and still have to access a lot of sstables to get data. |
173 | scylla_database_counter_cell_lock_acquisition | counter | The number of acquired counter cell locks. |
174 | scylla_database_counter_cell_lock_pending | gauge | The number of counter updates waiting for a lock. |
175 | scylla_database_disk_reads | gauge | Holds the number of currently active disk read operations. |
176 | scylla_database_dropped_view_updates | counter | Counts the number of view updates that have been dropped due to cluster overload. |
177 | scylla_database_large_partition_exceeding_threshold | counter | Number of large partitions exceeding compaction_large_partition_warning_threshold_mb. Large partitions have performance impact and should be avoided, check the documentation for details. |
178 | scylla_database_multishard_query_failed_reader_saves | counter | The number of times the saving of a shard reader failed. |
179 | scylla_database_multishard_query_failed_reader_stops | counter | The number of times the stopping of a shard reader failed. |
180 | scylla_database_multishard_query_unpopped_bytes | counter | The total number of bytes that were extracted from the shard reader but were unconsumed by the query and moved back into the reader. |
181 | scylla_database_multishard_query_unpopped_fragments | counter | The total number of fragments that were extracted from the shard reader but were unconsumed by the query and moved back into the reader. |
182 | scylla_database_paused_reads | gauge | The number of currently active reads that are temporarily paused. |
183 | scylla_database_paused_reads_permit_based_evictions | counter | 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. |
184 | scylla_database_querier_cache_drops | counter | Counts querier cache lookups that found a cached querier but had to drop it |
185 | scylla_database_querier_cache_lookups | counter | Counts querier cache lookups (paging queries) |
186 | scylla_database_querier_cache_misses | counter | Counts querier cache lookups that failed to find a cached querier |
187 | scylla_database_querier_cache_population | gauge | The number of entries currently in the querier cache. |
188 | scylla_database_querier_cache_resource_based_evictions | counter | Counts querier cache entries that were evicted to free up resources (limited by reader concurency limits) necessary to create new readers. |
189 | scylla_database_querier_cache_scheduling_group_mismatches | counter | Counts querier cache lookups that found a cached querier but had to drop it due to scheduling group mismatch |
190 | scylla_database_querier_cache_time_based_evictions | counter | Counts querier cache entries that timed out and were evicted. |
191 | scylla_database_queued_reads | gauge | Holds the number of currently queued read operations. |
192 | scylla_database_reads_memory_consumption | gauge | Holds the amount of memory consumed by current read operations. |
193 | scylla_database_reads_shed_due_to_overload | counter | 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. |
194 | scylla_database_requests_blocked_memory | counter | Holds the current number of requests blocked due to reaching the memory quota (444596224B). Non-zero value indicates that our bottleneck is memory and more specifically - the memory quota allocated for the "database" component. |
195 | scylla_database_requests_blocked_memory_current | gauge | Holds the current number of requests blocked due to reaching the memory quota (444596224B). Non-zero value indicates that our bottleneck is memory and more specifically - the memory quota allocated for the "database" component. |
196 | scylla_database_schema_changed | counter | The number of times the schema changed |
197 | scylla_database_short_data_queries | counter | The rate of data queries (data or digest reads) that returned less rows than requested due to result size limiting. |
198 | scylla_database_short_mutation_queries | counter | The rate of mutation queries that returned less rows than requested due to result size limiting. |
199 | scylla_database_sstable_read_queue_overloads | counter | 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. |
200 | scylla_database_sstables_read | gauge | Holds the number of currently read sstables. |
201 | scylla_database_total_reads | counter | Counts the total number of successful user reads on this shard. |
202 | scylla_database_total_reads_failed | counter | 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. |
203 | scylla_database_total_reads_rate_limited | counter | Counts read operations which were rejected on the replica side because the per-partition limit was reached. |
204 | scylla_database_total_result_bytes | gauge | Holds the current amount of memory used for results. |
205 | scylla_database_total_view_updates_failed_local | counter | Total number of view updates generated for tables and failed to be applied locally. |
206 | scylla_database_total_view_updates_failed_remote | counter | Total number of view updates generated for tables and failed to be sent to remote replicas. |
207 | scylla_database_total_view_updates_pushed_local | counter | Total number of view updates generated for tables and applied locally. |
208 | scylla_database_total_view_updates_pushed_remote | counter | Total number of view updates generated for tables and sent to remote replicas. |
209 | scylla_database_total_writes | counter | Counts the total number of successful write operations performed by this shard. |
210 | scylla_database_total_writes_failed | counter | Counts the total number of failed write operations. A sum of this value plus total_writes represents a total amount of writes attempted on this shard. |
211 | scylla_database_total_writes_rate_limited | counter | Counts write operations which were rejected on the replica side because the per-partition limit was reached. |
212 | scylla_database_total_writes_timedout | counter | Counts write operations failed due to a timeout. A positive value is a sign of storage being overloaded. |
213 | scylla_database_view_building_paused | counter | Counts the number of times view building process was paused (e.g. due to node unavailability). |
214 | scylla_database_view_update_backlog | gauge | Holds the current size in bytes of the pending view updates for all tables |
215 | scylla_execution_stages_function_calls_enqueued | counter | Counts function calls added to execution stages queues |
216 | scylla_execution_stages_function_calls_executed | counter | Counts function calls executed by execution stages |
217 | scylla_execution_stages_tasks_preempted | counter | Counts tasks which were preempted before execution all queued operations |
218 | scylla_execution_stages_tasks_scheduled | counter | Counts tasks scheduled by execution stages |
219 | scylla_forward_service_requests_dispatched_to_other_nodes | counter | how many forward requests were dispatched to other nodes |
220 | scylla_forward_service_requests_dispatched_to_own_shards | counter | how many forward requests were dispatched to local shards |
221 | scylla_forward_service_requests_executed | counter | how many forward requests were executed |
222 | scylla_gossip_heart_beat | counter | Heartbeat of the current Node. |
223 | scylla_gossip_live | gauge | How many live nodes the current node sees |
224 | scylla_gossip_unreachable | gauge | How many unreachable nodes the current node sees |
225 | scylla_hints_for_views_manager_corrupted_files | counter | Number of hints files that were discarded during sending because the file was corrupted. |
226 | scylla_hints_for_views_manager_discarded | counter | Number of hints that were discarded during sending (too old, schema changed, etc.). |
227 | scylla_hints_for_views_manager_dropped | counter | Number of dropped hints. |
228 | scylla_hints_for_views_manager_errors | counter | Number of errors during hints writes. |
229 | scylla_hints_for_views_manager_pending_drains | gauge | Number of tasks waiting in the queue for draining hints |
230 | scylla_hints_for_views_manager_pending_sends | gauge | Number of tasks waiting in the queue for sending a hint |
231 | scylla_hints_for_views_manager_sent | counter | Number of sent hints. |
232 | scylla_hints_for_views_manager_size_of_hints_in_progress | gauge | Size of hinted mutations that are scheduled to be written. |
233 | scylla_hints_for_views_manager_written | counter | Number of successfully written hints. |
234 | scylla_hints_manager_corrupted_files | counter | Number of hints files that were discarded during sending because the file was corrupted. |
235 | scylla_hints_manager_discarded | counter | Number of hints that were discarded during sending (too old, schema changed, etc.). |
236 | scylla_hints_manager_dropped | counter | Number of dropped hints. |
237 | scylla_hints_manager_errors | counter | Number of errors during hints writes. |
238 | scylla_hints_manager_pending_drains | gauge | Number of tasks waiting in the queue for draining hints |
239 | scylla_hints_manager_pending_sends | gauge | Number of tasks waiting in the queue for sending a hint |
240 | scylla_hints_manager_sent | counter | Number of sent hints. |
241 | scylla_hints_manager_size_of_hints_in_progress | gauge | Size of hinted mutations that are scheduled to be written. |
242 | scylla_hints_manager_written | counter | Number of successfully written hints. |
243 | scylla_httpd_connections_current | gauge | The current number of open connections |
244 | scylla_httpd_connections_total | counter | The total number of connections opened |
245 | scylla_httpd_read_errors | counter | The total number of errors while reading http requests |
246 | scylla_httpd_reply_errors | counter | The total number of errors while replying to http |
247 | scylla_httpd_requests_served | counter | The total number of http requests served |
248 | scylla_io_queue_adjusted_consumption | counter | Consumed disk capacity units adjusted for class shares and idling preemption |
249 | scylla_io_queue_consumption | counter | Accumulated disk capacity units consumed by this class; an increment per-second rate indicates full utilization |
250 | scylla_io_queue_delay | gauge | random delay time in the queue |
251 | scylla_io_queue_disk_queue_length | gauge | Number of requests in the disk |
252 | scylla_io_queue_queue_length | gauge | Number of requests in the queue |
253 | scylla_io_queue_shares | gauge | current amount of shares |
254 | scylla_io_queue_starvation_time_sec | counter | Total time spent starving for disk |
255 | scylla_io_queue_total_bytes | counter | Total bytes passed in the queue |
256 | scylla_io_queue_total_delay_sec | counter | Total time spent in the queue |
257 | scylla_io_queue_total_exec_sec | counter | Total time spent in disk |
258 | scylla_io_queue_total_operations | counter | Total operations passed in the queue |
259 | scylla_io_queue_total_read_bytes | counter | Total read bytes passed in the queue |
260 | scylla_io_queue_total_read_ops | counter | Total read operations passed in the queue |
261 | scylla_io_queue_total_split_bytes | counter | Total number of bytes split |
262 | scylla_io_queue_total_split_ops | counter | Total number of requests split |
263 | scylla_io_queue_total_write_bytes | counter | Total write bytes passed in the queue |
264 | scylla_io_queue_total_write_ops | counter | Total write operations passed in the queue |
265 | scylla_lsa_free_space | gauge | Holds a current amount of free memory that is under lsa control. |
266 | scylla_lsa_large_objects_total_space_bytes | gauge | Holds a current size of allocated non-LSA memory. |
267 | scylla_lsa_memory_allocated | counter | Counts number of bytes which were requested from LSA. |
268 | scylla_lsa_memory_compacted | counter | Counts number of bytes which were copied as part of segment compaction. |
269 | scylla_lsa_memory_evicted | counter | Counts number of bytes which were evicted. |
270 | scylla_lsa_memory_freed | counter | Counts number of bytes which were requested to be freed in LSA. |
271 | scylla_lsa_non_lsa_used_space_bytes | gauge | Holds a current amount of used non-LSA memory. |
272 | scylla_lsa_occupancy | gauge | Holds a current portion (in percents) of the used memory. |
273 | scylla_lsa_segments_compacted | counter | Counts a number of compacted segments. |
274 | scylla_lsa_small_objects_total_space_bytes | gauge | Holds a current size of "small objects" memory region in bytes. |
275 | scylla_lsa_small_objects_used_space_bytes | gauge | Holds a current amount of used "small objects" memory in bytes. |
276 | scylla_lsa_total_space_bytes | gauge | Holds a current size of allocated memory in bytes. |
277 | scylla_lsa_used_space_bytes | gauge | Holds a current amount of used memory in bytes. |
278 | scylla_memory_allocated_memory | gauge | Allocated memory size in bytes |
279 | scylla_memory_cross_cpu_free_operations | counter | Total number of cross cpu free |
280 | scylla_memory_dirty_bytes | gauge | Holds the current size of all ("regular", "system" and "streaming") non-free memory in bytes: used memory + released memory that hasn't been returned to a free memory pool yet. Total memory size minus this value represents the amount of available memory. If this value minus unspooled_dirty_bytes is too high then this means that the dirty memory eviction lags behind. |
281 | scylla_memory_free_memory | gauge | Free memory size in bytes |
282 | scylla_memory_free_operations | counter | Total number of free operations |
283 | scylla_memory_malloc_failed | counter | Total count of failed memory allocations |
284 | scylla_memory_malloc_live_objects | gauge | Number of live objects |
285 | scylla_memory_malloc_operations | counter | Total number of malloc operations |
286 | scylla_memory_reclaims_operations | counter | Total reclaims operations |
287 | scylla_memory_regular_dirty_bytes | gauge | Holds the current size of a all non-free memory in bytes: used memory + released memory that hasn't been returned to a free memory pool yet. Total memory size minus this value represents the amount of available memory. If this value minus unspooled_dirty_bytes is too high then this means that the dirty memory eviction lags behind. |
288 | scylla_memory_regular_unspooled_dirty_bytes | gauge | Holds the size of used memory in bytes. Compare it to "dirty_bytes" to see how many memory is wasted (neither used nor available). |
289 | scylla_memory_system_dirty_bytes | gauge | Holds the current size of a all non-free memory in bytes: used memory + released memory that hasn't been returned to a free memory pool yet. Total memory size minus this value represents the amount of available memory. If this value minus unspooled_dirty_bytes is too high then this means that the dirty memory eviction lags behind. |
290 | scylla_memory_system_unspooled_dirty_bytes | gauge | Holds the size of used memory in bytes. Compare it to "dirty_bytes" to see how many memory is wasted (neither used nor available). |
291 | scylla_memory_total_memory | gauge | Total memory size in bytes |
292 | scylla_memory_unspooled_dirty_bytes | gauge | Holds the size of all ("regular", "system" and "streaming") used memory in bytes. Compare it to "dirty_bytes" to see how many memory is wasted (neither used nor available). |
293 | scylla_memtables_failed_flushes | gauge | Holds the number of failed memtable flushes. High value in this metric may indicate a permanent failure to flush a memtable. |
294 | scylla_memtables_pending_flushes | gauge | Holds the current number of memtables that are currently being flushed to sstables. High value in this metric may be an indication of storage being a bottleneck. |
295 | scylla_memtables_pending_flushes_bytes | gauge | Holds the current number of bytes in memtables that are currently being flushed to sstables. High value in this metric may be an indication of storage being a bottleneck. |
296 | scylla_node_operation_mode | gauge | 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 |
297 | scylla_node_ops_finished_percentage | gauge | Finished percentage of node operation on this shard |
298 | scylla_per_partition_rate_limiter_allocations | counter | Number of times a entry was allocated over an empty/expired entry. |
299 | scylla_per_partition_rate_limiter_failed_allocations | counter | Number of times the rate limiter gave up trying to allocate. |
300 | scylla_per_partition_rate_limiter_load_factor | gauge | Current load factor of the hash table (upper bound, may be overestimated). |
301 | scylla_per_partition_rate_limiter_probe_count | counter | Number of probes made during lookups. |
302 | scylla_per_partition_rate_limiter_successful_lookups | counter | Number of times a lookup returned an already allocated entry. |
303 | scylla_query_processor_queries | counter | Counts queries by consistency level. |
304 | scylla_query_processor_statements_prepared | counter | Counts the total number of parsed CQL requests. |
305 | scylla_raft_group0_status | gauge | status of the raft group, 0 - disabled, 1 - normal, 2 - aborted |
306 | scylla_reactor_abandoned_failed_futures | counter | Total number of abandoned failed futures, futures destroyed while still containing an exception |
307 | scylla_reactor_aio_bytes_read | counter | Total aio-reads bytes |
308 | scylla_reactor_aio_bytes_write | counter | Total aio-writes bytes |
309 | scylla_reactor_aio_errors | counter | Total aio errors |
310 | scylla_reactor_aio_outsizes | counter | Total number of aio operations that exceed IO limit |
311 | scylla_reactor_aio_reads | counter | Total aio-reads operations |
312 | scylla_reactor_aio_writes | counter | Total aio-writes operations |
313 | scylla_reactor_cpp_exceptions | counter | Total number of C++ exceptions |
314 | scylla_reactor_cpu_busy_ms | counter | Total cpu busy time in milliseconds |
315 | scylla_reactor_cpu_steal_time_ms | counter | Total steal time, the time in which some other process was running while Seastar was not trying to run (not sleeping).Because this is in userspace, some time that could be legitimally thought as steal time is not accounted as such. For example, if we are sleeping and can wake up but the kernel hasn't woken us up yet. |
316 | scylla_reactor_fstream_read_bytes | counter | Counts bytes read from disk file streams. A high rate indicates high disk activity. Divide by fstream_reads to determine average read size. |
317 | scylla_reactor_fstream_read_bytes_blocked | counter | Counts the number of bytes read from disk that could not be satisfied from read-ahead buffers, and had to block. Indicates short streams, or incorrect read ahead configuration. |
318 | scylla_reactor_fstream_reads | counter | Counts reads from disk file streams. A high rate indicates high disk activity. Contrast with other fstream_read* counters to locate bottlenecks. |
319 | scylla_reactor_fstream_reads_ahead_bytes_discarded | counter | Counts the number of buffered bytes that were read ahead of time and were discarded because they were not needed, wasting disk bandwidth. Indicates over-eager read ahead configuration. |
320 | scylla_reactor_fstream_reads_aheads_discarded | counter | Counts the number of times a buffer that was read ahead of time and was discarded because it was not needed, wasting disk bandwidth. Indicates over-eager read ahead configuration. |
321 | scylla_reactor_fstream_reads_blocked | counter | Counts the number of times a disk read could not be satisfied from read-ahead buffers, and had to block. Indicates short streams, or incorrect read ahead configuration. |
322 | scylla_reactor_fsyncs | counter | Total number of fsync operations |
323 | scylla_reactor_io_threaded_fallbacks | counter | Total number of io-threaded-fallbacks operations |
324 | scylla_reactor_logging_failures | counter | Total number of logging failures |
325 | scylla_reactor_polls | counter | Number of times pollers were executed |
326 | scylla_reactor_tasks_pending | gauge | Number of pending tasks in the queue |
327 | scylla_reactor_tasks_processed | counter | Total tasks processed |
328 | scylla_reactor_timers_pending | gauge | Number of tasks in the timer-pending queue |
329 | scylla_reactor_utilization | gauge | CPU utilization |
330 | scylla_repair_row_from_disk_bytes | counter | Total bytes of rows read from disk on this shard. |
331 | scylla_repair_row_from_disk_nr | counter | Total number of rows read from disk on this shard. |
332 | scylla_repair_rx_hashes_nr | counter | Total number of row hashes received on this shard. |
333 | scylla_repair_rx_row_bytes | counter | Total bytes of rows received on this shard. |
334 | scylla_repair_rx_row_nr | counter | Total number of rows received on this shard. |
335 | scylla_repair_tx_hashes_nr | counter | Total number of row hashes sent on this shard. |
336 | scylla_repair_tx_row_bytes | counter | Total bytes of rows sent on this shard. |
337 | scylla_repair_tx_row_nr | counter | Total number of rows sent on this shard. |
338 | scylla_scheduler_queue_length | gauge | Size of backlog on this queue, in tasks; indicates whether the queue is busy and/or contended |
339 | scylla_scheduler_runtime_ms | counter | Accumulated runtime of this task queue; an increment rate of 1000ms per second indicates full utilization |
340 | scylla_scheduler_shares | gauge | Shares allocated to this queue |
341 | scylla_scheduler_starvetime_ms | counter | Accumulated starvation time of this task queue; an increment rate of 1000ms per second indicates the scheduler feels really bad |
342 | scylla_scheduler_tasks_processed | counter | Count of tasks executing on this queue; indicates together with runtime_ms indicates length of tasks |
343 | scylla_scheduler_time_spent_on_task_quota_violations_ms | counter | Total amount in milliseconds we were in violation of the task quota |
344 | scylla_scheduler_waittime_ms | counter | Accumulated waittime of this task queue; an increment rate of 1000ms per second indicates queue is waiting for something (e.g. IO) |
345 | scylla_schema_commitlog_active_allocations | gauge | Current number of active allocations. |
346 | scylla_schema_commitlog_alloc | counter | Counts number of times a new mutation has been added to a segment. Divide bytes_written by this value to get the average number of bytes per mutation written to the disk. |
347 | scylla_schema_commitlog_allocating_segments | gauge | Holds the number of not closed segments that still have some free space. This value should not get too high. |
348 | scylla_schema_commitlog_blocked_on_new_segment | gauge | Number of allocations blocked on acquiring new segment. |
349 | scylla_schema_commitlog_bytes_flush_requested | counter | Counts number of bytes requested to be flushed (persisted). |
350 | scylla_schema_commitlog_bytes_released | counter | Counts number of bytes released from disk. (Deleted/recycled) |
351 | scylla_schema_commitlog_bytes_written | counter | Counts number of bytes written to the disk. Divide this value by "alloc" to get the average number of bytes per mutation written to the disk. |
352 | scylla_schema_commitlog_cycle | counter | Counts number of commitlog write cycles - when the data is written from the internal memory buffer to the disk. |
353 | scylla_schema_commitlog_disk_active_bytes | gauge | Holds size of disk space in bytes used for data so far. A too high value indicates that we have some bottleneck in the writing to sstables path. |
354 | scylla_schema_commitlog_disk_slack_end_bytes | gauge | Holds size of disk space in bytes unused because of segment switching (end slack). A too high value indicates that we do not write enough data to each segment. |
355 | scylla_schema_commitlog_disk_total_bytes | gauge | Holds size of disk space in bytes reserved for data so far. A too high value indicates that we have some bottleneck in the writing to sstables path. |
356 | scylla_schema_commitlog_flush | counter | Counts number of times the flush() method was called for a file. |
357 | scylla_schema_commitlog_flush_limit_exceeded | counter | Counts number of times a flush limit was exceeded. A non-zero value indicates that there are too many pending flush operations (see pending_flushes) and some of them will be blocked till the total amount of pending flush operations drops below 5. |
358 | scylla_schema_commitlog_memory_buffer_bytes | gauge | Holds the total number of bytes in internal memory buffers. |
359 | scylla_schema_commitlog_pending_allocations | gauge | Holds number of currently pending allocations. A non-zero value indicates that we have a bottleneck in the disk write flow. |
360 | scylla_schema_commitlog_pending_flushes | gauge | Holds number of currently pending flushes. See the related flush_limit_exceeded metric. |
361 | scylla_schema_commitlog_requests_blocked_memory | counter | Counts number of requests blocked due to memory pressure. A non-zero value indicates that the commitlog memory quota is not enough to serve the required amount of requests. |
362 | scylla_schema_commitlog_segments | gauge | Holds the current number of segments. |
363 | scylla_schema_commitlog_slack | counter | Counts number of unused bytes written to the disk due to disk segment alignment. |
364 | scylla_schema_commitlog_unused_segments | gauge | Holds the current number of unused segments. A non-zero value indicates that the disk write path became temporary slow. |
365 | scylla_scylladb_current_version | gauge | Current ScyllaDB version. |
366 | scylla_sstables_bloom_filter_memory_size | gauge | Bloom filter memory usage in bytes. |
367 | scylla_sstables_capped_local_deletion_time | counter | Was local deletion time capped at maximum allowed value in Statistics |
368 | scylla_sstables_capped_tombstone_deletion_time | counter | Was partition tombstone deletion time capped at maximum allowed value |
369 | scylla_sstables_cell_tombstone_writes | counter | Number of cell tombstones written |
370 | scylla_sstables_cell_writes | counter | Number of cells written |
371 | scylla_sstables_currently_open_for_reading | gauge | Number of sstables currently open for reading |
372 | scylla_sstables_currently_open_for_writing | gauge | Number of sstables currently open for writing |
373 | scylla_sstables_index_page_blocks | counter | Index page requests which needed to wait due to page not being loaded yet |
374 | scylla_sstables_index_page_cache_bytes | gauge | Total number of bytes cached in the index page cache |
375 | scylla_sstables_index_page_cache_bytes_in_std | gauge | Total number of bytes in temporary buffers which live in the std allocator |
376 | scylla_sstables_index_page_cache_evictions | counter | Total number of index page cache pages which have been evicted |
377 | scylla_sstables_index_page_cache_hits | counter | Index page cache requests which were served from cache |
378 | scylla_sstables_index_page_cache_misses | counter | Index page cache requests which had to perform I/O |
379 | scylla_sstables_index_page_cache_populations | counter | Total number of index page cache pages which were inserted into the cache |
380 | scylla_sstables_index_page_evictions | counter | Index pages which got evicted from memory |
381 | scylla_sstables_index_page_hits | counter | Index page requests which could be satisfied without waiting |
382 | scylla_sstables_index_page_misses | counter | Index page requests which initiated a read from disk |
383 | scylla_sstables_index_page_populations | counter | Index pages which got populated into memory |
384 | scylla_sstables_index_page_used_bytes | gauge | Amount of bytes used by index pages in memory |
385 | scylla_sstables_partition_reads | counter | Number of partitions read |
386 | scylla_sstables_partition_seeks | counter | Number of partitions seeked |
387 | scylla_sstables_partition_writes | counter | Number of partitions written |
388 | scylla_sstables_pi_auto_scale_events | counter | Number of promoted index auto-scaling events |
389 | scylla_sstables_pi_cache_block_count | gauge | Number of promoted index blocks currently cached |
390 | scylla_sstables_pi_cache_bytes | gauge | Number of bytes currently used by cached promoted index blocks |
391 | scylla_sstables_pi_cache_evictions | counter | Number of promoted index blocks which got evicted |
392 | scylla_sstables_pi_cache_hits_l0 | counter | Number of requests for promoted index block in state l0 which didn't have to go to the page cache |
393 | scylla_sstables_pi_cache_hits_l1 | counter | Number of requests for promoted index block in state l1 which didn't have to go to the page cache |
394 | scylla_sstables_pi_cache_hits_l2 | counter | Number of requests for promoted index block in state l2 which didn't have to go to the page cache |
395 | scylla_sstables_pi_cache_misses_l0 | counter | Number of requests for promoted index block in state l0 which had to go to the page cache |
396 | scylla_sstables_pi_cache_misses_l1 | counter | Number of requests for promoted index block in state l1 which had to go to the page cache |
397 | scylla_sstables_pi_cache_misses_l2 | counter | Number of requests for promoted index block in state l2 which had to go to the page cache |
398 | scylla_sstables_pi_cache_populations | counter | Number of promoted index blocks which got inserted |
399 | scylla_sstables_range_partition_reads | counter | Number of partition range flat mutation reads |
400 | scylla_sstables_range_tombstone_reads | counter | Number of range tombstones read |
401 | scylla_sstables_range_tombstone_writes | counter | Number of range tombstones written |
402 | scylla_sstables_row_reads | counter | Number of rows read |
403 | scylla_sstables_row_tombstone_reads | counter | Number of row tombstones read |
404 | scylla_sstables_row_writes | counter | Number of clustering rows written |
405 | scylla_sstables_single_partition_reads | counter | Number of single partition flat mutation reads |
406 | scylla_sstables_static_row_writes | counter | Number of static rows written |
407 | scylla_sstables_tombstone_writes | counter | Number of tombstones written |
408 | scylla_sstables_total_deleted | counter | Counter of deleted sstables |
409 | scylla_sstables_total_open_for_reading | counter | Counter of sstables open for reading |
410 | scylla_sstables_total_open_for_writing | counter | Counter of sstables open for writing |
411 | scylla_stall_detector_reported | counter | Total number of reported stalls, look in the traces for the exact reason |
412 | scylla_storage_proxy_coordinator_background_read_repairs | counter | number of background read repairs |
413 | scylla_storage_proxy_coordinator_background_reads | gauge | number of currently pending background read requests |
414 | scylla_storage_proxy_coordinator_background_replica_writes_failed_local_node | counter | number of replica writes that timed out or failed after CL was reachedon a local Node |
415 | scylla_storage_proxy_coordinator_background_replica_writes_failed_remote_node | counter | number of replica writes that timed out or failed after CL was reached when communicating with external Nodes in another DC |
416 | scylla_storage_proxy_coordinator_background_writes | gauge | number of currently pending background write requests |
417 | scylla_storage_proxy_coordinator_background_writes_failed | counter | number of write requests that failed after CL was reached |
418 | scylla_storage_proxy_coordinator_cas_background | gauge | how many paxos operations are still running after a result was alredy returned |
419 | scylla_storage_proxy_coordinator_cas_failed_read_round_optimization | counter | CAS read rounds issued only if previous value is missing on some replica |
420 | scylla_storage_proxy_coordinator_cas_foreground | gauge | how many paxos operations that did not yet produce a result are running |
421 | scylla_storage_proxy_coordinator_cas_prune | counter | how many times paxos prune was done after successful cas operation |
422 | scylla_storage_proxy_coordinator_cas_total_operations | counter | number of total paxos operations executed (reads and writes) |
423 | scylla_storage_proxy_coordinator_cas_write_contention | histogram | how many contended writes were encountered |
424 | scylla_storage_proxy_coordinator_cas_write_latency | histogram | Transactional write latency histogram |
425 | scylla_storage_proxy_coordinator_cas_write_latency_summary | summary | CAS write latency summary |
426 | scylla_storage_proxy_coordinator_completed_reads_local_node | counter | number of data read requests that completedon a local Node |
427 | scylla_storage_proxy_coordinator_completed_reads_remote_node | counter | number of data read requests that completed when communicating with external Nodes in another DC |
428 | scylla_storage_proxy_coordinator_current_throttled_base_writes | gauge | number of currently throttled base replica write requests |
429 | scylla_storage_proxy_coordinator_current_throttled_writes | gauge | number of currently throttled write requests |
430 | scylla_storage_proxy_coordinator_foreground_read_repairs | counter | number of foreground read repairs |
431 | scylla_storage_proxy_coordinator_foreground_reads | gauge | number of currently pending foreground read requests |
432 | scylla_storage_proxy_coordinator_foreground_writes | gauge | number of currently pending foreground write requests |
433 | scylla_storage_proxy_coordinator_last_mv_flow_control_delay | gauge | delay (in seconds) added for MV flow control in the last request |
434 | scylla_storage_proxy_coordinator_read_errors_local_node | counter | number of data read requests that failedon a local Node |
435 | scylla_storage_proxy_coordinator_read_errors_remote_node | counter | number of data read requests that failed when communicating with external Nodes in another DC |
436 | scylla_storage_proxy_coordinator_read_latency | histogram | The general read latency histogram |
437 | scylla_storage_proxy_coordinator_read_latency_summary | summary | Read latency summary |
438 | scylla_storage_proxy_coordinator_read_repair_write_attempts_local_node | counter | number of write operations in a read repair contexton a local Node |
439 | scylla_storage_proxy_coordinator_read_repair_write_attempts_remote_node | counter | number of write operations in a read repair context when communicating with external Nodes in another DC |
440 | scylla_storage_proxy_coordinator_read_timeouts | counter | number of read request failed due to a timeout |
441 | scylla_storage_proxy_coordinator_reads_local_node | counter | number of data read requestson a local Node |
442 | scylla_storage_proxy_coordinator_reads_remote_node | counter | number of data read requests when communicating with external Nodes in another DC |
443 | scylla_storage_proxy_coordinator_speculative_data_reads | counter | number of speculative data read requests that were sent |
444 | scylla_storage_proxy_coordinator_speculative_digest_reads | counter | number of speculative digest read requests that were sent |
445 | scylla_storage_proxy_coordinator_total_write_attempts_local_node | counter | total number of write requestson a local Node |
446 | scylla_storage_proxy_coordinator_total_write_attempts_remote_node | counter | total number of write requests when communicating with external Nodes in another DC |
447 | scylla_storage_proxy_coordinator_write_errors_local_node | counter | number of write requests that failedon a local Node |
448 | scylla_storage_proxy_coordinator_write_latency | histogram | The general write latency histogram |
449 | scylla_storage_proxy_coordinator_write_latency_summary | summary | Write latency summary |
450 | scylla_storage_proxy_coordinator_write_timeouts | counter | number of write request failed due to a timeout |
451 | scylla_storage_proxy_replica_cross_shard_ops | counter | number of operations that crossed a shard boundary |
452 | scylla_storage_proxy_replica_reads | counter | number of remote data read requests this Node received |
453 | scylla_storage_proxy_replica_received_mutations | counter | number of mutations received by a replica Node |
454 | scylla_streaming_finished_percentage | gauge | Finished percentage of node operation on this shard |
455 | scylla_streaming_total_incoming_bytes | counter | Total number of bytes received on this shard. |
456 | scylla_streaming_total_outgoing_bytes | counter | Total number of bytes sent on this shard. |
457 | scylla_tracing_active_sessions | gauge | Holds a number of a currently active tracing sessions. |
458 | scylla_tracing_cached_records | gauge | Holds a number of tracing records cached in the tracing sessions that are not going to be written in the next write event. If sum of this metric, pending_for_write_records and flushing_records is close to 11000 we are likely to start dropping tracing records. |
459 | scylla_tracing_dropped_records | counter | Counts a number of dropped records due to too many pending records. High value indicates that backend is saturated with the rate with which new tracing records are created. |
460 | scylla_tracing_dropped_sessions | counter | Counts a number of dropped sessions due to too many pending sessions/records. High value indicates that backend is saturated with the rate with which new tracing records are created. |
461 | scylla_tracing_flushing_records | gauge | Holds a number of tracing records that currently being written to the I/O backend. If sum of this metric, cached_records and pending_for_write_records is close to 11000 we are likely to start dropping tracing records. |
462 | scylla_tracing_keyspace_helper_bad_column_family_errors | counter | 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. |
463 | scylla_tracing_keyspace_helper_tracing_errors | counter | Counts a number of errors during writing to a system_traces keyspace. One error may cause one or more tracing records to be lost. |
464 | scylla_tracing_pending_for_write_records | gauge | Holds a number of tracing records that are going to be written in the next write event. If sum of this metric, cached_records and flushing_records is close to 11000 we are likely to start dropping tracing records. |
465 | scylla_tracing_trace_errors | counter | Counts a number of trace records dropped due to an error (e.g. OOM). |
466 | scylla_tracing_trace_records_count | counter | This metric is a rate of tracing records generation. |
467 | scylla_transport_auth_responses | counter | Counts the total number of received CQL AUTH messages. |
468 | scylla_transport_batch_requests | counter | Counts the total number of received CQL BATCH messages. |
469 | scylla_transport_cql_connections | counter | Counts a number of client connections. |
470 | scylla_transport_cql_errors_total | counter | Counts the total number of returned CQL errors. |
471 | scylla_transport_current_connections | gauge | Holds a current number of client connections. |
472 | scylla_transport_execute_requests | counter | Counts the total number of received CQL EXECUTE messages. |
473 | scylla_transport_options_requests | counter | Counts the total number of received CQL OPTIONS messages. |
474 | scylla_transport_prepare_requests | counter | Counts the total number of received CQL PREPARE messages. |
475 | scylla_transport_query_requests | counter | Counts the total number of received CQL QUERY messages. |
476 | scylla_transport_register_requests | counter | Counts the total number of received CQL REGISTER messages. |
477 | scylla_transport_requests_blocked_memory | counter | Holds an incrementing counter with the requests that ever blocked due to reaching the memory quota limit (177838489B). The first derivative of this value shows how often we block due to memory exhaustion in the "CQL transport" component. |
478 | scylla_transport_requests_blocked_memory_current | gauge | Holds the number of requests that are currently blocked due to reaching the memory quota limit (177838489B). Non-zero value indicates that our bottleneck is memory and more specifically - the memory quota allocated for the "CQL transport" component. |
479 | scylla_transport_requests_memory_available | gauge | Holds the amount of available memory for admitting new requests (max is 177838489B).Zero value indicates that our bottleneck is memory and more specifically - the memory quota allocated for the "CQL transport" component. |
480 | scylla_transport_requests_served | counter | Counts a number of served requests. |
481 | scylla_transport_requests_serving | gauge | Holds a number of requests that are being processed right now. |
482 | scylla_transport_requests_shed | counter | Holds an incrementing counter with the requests that were shed due to overload (threshold configured via max_concurrent_requests_per_shard). The first derivative of this value shows how often we shed requests due to overload in the "CQL transport" component. |
483 | scylla_transport_startups | counter | Counts the total number of received CQL STARTUP messages. |
484 | scylla_view_builder_builds_in_progress | gauge | Number of currently active view builds. |
485 | scylla_view_builder_pending_bookkeeping_ops | gauge | Number of tasks waiting to perform bookkeeping operations |
486 | scylla_view_builder_steps_failed | counter | Number of failed build steps. |
487 | scylla_view_builder_steps_performed | counter | Number of performed build steps. |
488 | scylla_view_update_generator_pending_registrations | gauge | Number of tasks waiting to register staging sstables |
489 | scylla_view_update_generator_queued_batches_count | gauge | Number of sets of sstables queued for view update generation |
490 | scylla_view_update_generator_sstables_pending_work | gauge | Number of bytes remaining to be processed from SSTables for view updates |
491 | scylla_view_update_generator_sstables_to_move_count | gauge | Number of sets of sstables which are already processed and wait to be moved from their staging directory |