General Monitoring Metrics
This topic introduces some important general metrics of StarRocks.
For dedicated metrics for materialized views and shared-data clusters, please refer to the corresponding sections:
- Metrics for asynchronous materialized view metrics
- Metrics for Shared-data Dashboard metrics, and Starlet Dashboard metrics
For more information on how to build a monitoring service for your StarRocks cluster, see Monitor and Alert.
Metric items
be_broker_count
- Unit: Count
- Type: Average
- Description: Number of brokers.
be_brpc_endpoint_count
- Unit: Count
- Type: Average
- Description: Number of StubCache in bRPC.
be_bytes_read_per_second
- Unit: Bytes/s
- Type: Average
- Description: Read speed of BE.
be_bytes_written_per_second
- Unit: Bytes/s
- Type: Average
- Description: Write speed of BE.
be_base_compaction_bytes_per_second
- Unit: Bytes/s
- Type: Average
- Description: Base compaction speed of BE.
be_cumulative_compaction_bytes_per_second
- Unit: Bytes/s
- Type: Average
- Description: Cumulative compaction speed of BE.
be_base_compaction_rowsets_per_second
- Unit: Count
- Type: Average
- Description: Base compaction speed of BE rowsets.
be_cumulative_compaction_rowsets_per_second
- Unit: Count
- Type: Average
- Description: Cumulative compaction speed of BE rowsets.
be_base_compaction_failed
- Unit: Count/s
- Type: Average
- Description: Base compaction failure of BE.
be_clone_failed
- Unit: Count/s
- Type: Average
- Description: BE clone failure.
be_create_rollup_failed
- Unit: Count/s
- Type: Average
- Description: Materialized view creation failure of BE.
be_create_tablet_failed
- Unit: Count/s
- Type: Average
- Description: Tablet creation failure of BE.
be_cumulative_compaction_failed
- Unit: Count/s
- Type: Average
- Description: Cumulative compaction failure of BE.
be_delete_failed
- Unit: Count/s
- Type: Average
- Description: Delete failure of BE.
be_finish_task_failed
- Unit: Count/s
- Type: Average
- Description: Task failure of BE.
be_publish_failed
- Unit: Count/s
- Type: Average
- Description: Version release failure of BE.
be_report_tables_failed
- Unit: Count/s
- Type: Average
- Description: Table report failure of BE.
be_report_disk_failed
- Unit: Count/s
- Type: Average
- Description: Disk report failure of BE.
be_report_tablet_failed
- Unit: Count/s
- Type: Average
- Description: Tablet report failure of BE.
be_report_task_failed
- Unit: Count/s
- Type: Average
- Description: Task report failure of BE.
be_schema_change_failed
- Unit: Count/s
- Type: Average
- Description: Schema change failure of BE.
be_base_compaction_requests
- Unit: Count/s
- Type: Average
- Description: Base compaction request of BE.
be_clone_total_requests
- Unit: Count/s
- Type: Average
- Description: Clone request of BE.
be_create_rollup_requests
- Unit: Count/s
- Type: Average
- Description: Materialized view creation request of BE.
be_create_tablet_requests
- Unit: Count/s
- Type: Average
- Description: Tablet creation request of BE.
be_cumulative_compaction_requests
- Unit: Count/s
- Type: Average
- Description: Cumulative compaction request of BE.
be_delete_requests
- Unit: Count/s
- Type: Average
- Description: Delete request of BE.
be_finish_task_requests
- Unit: Count/s
- Type: Average
- Description: Task finish request of BE.
be_publish_requests
- Unit: Count/s
- Type: Average
- Description: Version publish request of BE.
be_report_tablets_requests
- Unit: Count/s
- Type: Average
- Description: Tablet report request of BE.
be_report_disk_requests
- Unit: Count/s
- Type: Average
- Description: Disk report request of BE.
be_report_tablet_requests
- Unit: Count/s
- Type: Average
- Description: Tablet report request of BE.
be_report_task_requests
- Unit: Count/s
- Type: Average
- Description: Task report request of BE.
be_schema_change_requests
- Unit: Count/s
- Type: Average
- Description: Schema change report request of BE.
be_storage_migrate_requests
- Unit: Count/s
- Type: Average
- Description: Migration request of BE.
be_fragment_endpoint_count
- Unit: Count
- Type: Average
- Description: Number of BE DataStream.
be_fragment_request_latency_avg
- Unit: ms
- Type: Average
- Description: Latency of fragment requests.
be_fragment_requests_per_second
- Unit: Count/s
- Type: Average
- Description: Number of fragment requests.
be_http_request_latency_avg
- Unit: ms
- Type: Average
- Description: Latency of HTTP requests.
be_http_requests_per_second
- Unit: Count/s
- Type: Average
- Description: Number of HTTP requests.
be_http_request_send_bytes_per_second
- Unit: Bytes/s
- Type: Average
- Description: Number of bytes sent for HTTP requests.
fe_connections_per_second
- Unit: Count/s
- Type: Average
- Description: New connection rate of FE.
fe_connection_total
- Unit: Count
- Type: Cumulative
- Description: Total number of FE connections.
fe_edit_log_read
- Unit: Count/s
- Type: Average
- Description: Read speed of FE edit log.
fe_edit_log_size_bytes
- Unit: Bytes/s
- Type: Average
- Description: Size of FE edit log.
fe_edit_log_write
- Unit: Bytes/s
- Type: Average
- Description: Write speed of FE edit log.
fe_checkpoint_push_per_second
- Unit: Count/s
- Type: Average
- Description: Number of FE checkpoints.
fe_pending_hadoop_load_job
- Unit: Count
- Type: Average
- Description: Number of pending hadoop jobs.
fe_committed_hadoop_load_job
- Unit: Count
- Type: Average
- Description: Number of committed hadoop jobs.
fe_loading_hadoop_load_job
- Unit: Count
- Type: Average
- Description: Number of loading hadoop jobs.
fe_finished_hadoop_load_job
- Unit: Count
- Type: Average
- Description: Number of completedhadoop jobs.
fe_cancelled_hadoop_load_job
- Unit: Count
- Type: Average
- Description: Number of cancelled hadoop jobs.
fe_pending_insert_load_job
- Unit: Count
- Type: Average
- Description: Number of pending insert jobs.
fe_loading_insert_load_job
- Unit: Count
- Type: Average
- Description: Number of loading insert jobs.
fe_committed_insert_load_job
- Unit: Count
- Type: Average
- Description: Number of committed insert jobs.
fe_finished_insert_load_job
- Unit: Count
- Type: Average
- Description: Number of completed insert jobs.
fe_cancelled_insert_load_job
- Unit: Count
- Type: Average
- Description: Number of cancelled insert jobs.
fe_pending_broker_load_job
- Unit: Count
- Type: Average
- Description: Number of pending broker jobs.
fe_loading_broker_load_job
- Unit: Count
- Type: Average
- Description: Number of loading broker jobs.
fe_committed_broker_load_job
- Unit: Count
- Type: Average
- Description: Number of committed broker jobs.
fe_finished_broker_load_job
- Unit: Count
- Type: Average
- Description: Number of finished broker jobs.
fe_cancelled_broker_load_job
- Unit: Count
- Type: Average
- Description: Number of cancelled broker jobs.
fe_pending_delete_load_job
- Unit: Count
- Type: Average
- Description: Number of pending delete jobs.
fe_loading_delete_load_job
- Unit: Count
- Type: Average
- Description: Number of loading delete jobs.
fe_committed_delete_load_job
- Unit: Count
- Type: Average
- Description: Number of committed delete jobs.
fe_finished_delete_load_job
- Unit: Count
- Type: Average
- Description: Number of finished delete jobs.
fe_cancelled_delete_load_job
- Unit: Count
- Type: Average
- Description: Number of cancelled delete jobs.
fe_rollup_running_alter_job
- Unit: Count
- Type: Average
- Description: Number of jobs created in rollup.
fe_schema_change_running_job
- Unit: Count
- Type: Average
- Description: Number of jobs in schema change.
cpu_util
- Unit: -
- Type: Average
- Description: CPU usage rate.
cpu_system
- Unit: -
- Type: Average
- Description: cpu_system usage rate.
cpu_user
- Unit: -
- Type: Average
- Description: cpu_user usage rate.
cpu_idle
- Unit: -
- Type: Average
- Description: cpu_idle usage rate.
cpu_guest
- Unit: -
- Type: Average
- Description: cpu_guest usage rate.
cpu_iowait
- Unit: -
- Type: Average
- Description: cpu_iowait usage rate.
cpu_irq
- Unit: -
- Type: Average
- Description: cpu_irq usage rate.
cpu_nice
- Unit: -
- Type: Average
- Description: cpu_nice usage rate.
cpu_softirq
- Unit: -
- Type: Average
- Description: cpu_softirq usage rate.
cpu_steal
- Unit: -
- Type: Average
- Description: cpu_steal usage rate.
disk_free
- Unit: Bytes
- Type: Average
- Description: Free disk capacity.
disk_io_svctm
- Unit: ms
- Type: Average
- Description: Disk IO service time.
disk_io_util
- Unit: -
- Type: Average
- Description: Disk usage.
disk_used
- Unit: Bytes
- Type: Average
- Description: Used disk capacity.
encryption_keys_created
- Unit: Count
- Type: Cumulative
- Description: number of file encryption keys created for file encryption
encryption_keys_unwrapped
- Unit: Count
- Type: Cumulative
- Description: number of encryption meta unwrapped for file decryption
encryption_keys_in_cache
- Unit: Count
- Type: Instantaneous
- Description: number of encryption keys currently in key cache
starrocks_fe_meta_log_count
- Unit: Count
- Type: Instantaneous
- Description: The number of Edit Logs without a checkpoint. A value within
100000
is considered reasonable..
starrocks_fe_query_resource_group
- Unit: Count
- Type: Cumulative
- Description: The number of queries for each resource group.
starrocks_fe_query_resource_group_latency
- Unit: Seconds
- Type: Average
- Description: the query latency percentile for each resource group.
starrocks_fe_query_resource_group_err
- Unit: Count
- Type: Cumulative
- Description: The number of incorrect queries for each resource group.
starrocks_be_resource_group_cpu_limit_ratio
- Unit: -
- Type: Instantaneous
- Description: Instantaneous value of resource group cpu quota ratio.
starrocks_be_resource_group_cpu_use_ratio
- Unit: -
- Type: Average
- Description: The ratio of CPU time used by the resource group to the CPU time of all resource groups.
starrocks_be_resource_group_mem_limit_bytes
- Unit: Bytes
- Type: Instantaneous
- Description: Instantaneous value of resource group memory quota.
starrocks_be_resource_group_mem_allocated_bytes
- Unit: Bytes
- Type: Instantaneous
- Description: Instantaneous value of resource group memory usage.
starrocks_be_pipe_prepare_pool_queue_len
- Unit: Count
- Type: Instantaneous
- Description: Instantaneous value of pipeline prepare thread pool task queue length.
starrocks_fe_safe_mode
- Unit: -
- Type: Instantaneous
- Description: Indicates whether Safe Mode is enabled. Valid values:
0
(disabled) and1
(enabled). When Safe Mode is enabled, the cluster no longer accepts any loading requests.
starrocks_fe_unfinished_backup_job
- Unit: Count
- Type: Instantaneous
- Description: Indicates the number of running BACKUP tasks under the specific warehouse. For a shared-nothing cluster, this item only monitors the default warehouse. For a shared-data cluster, this value is always
0
.
starrocks_fe_unfinished_restore_job
- Unit: Count
- Type: Instantaneous
- Description: Indicates the number of running RESTORE tasks under the specific warehouse. For a shared-nothing cluster, this item only monitors the default warehouse. For a shared-data cluster, this value is always
0
.
starrocks_fe_memory
- Unit: Bytes or Count
- Type: Instantaneous
- Description: Indicates the memory statistics for various modules under the specific warehouse. For a shared-nothing cluster, this item only monitors the default warehouse.
starrocks_fe_unfinished_query
- Unit: Count
- Type: Instantaneous
- Description: Indicates the number of queries currently running under the specific warehouse. For a shared-nothing cluster, this item only monitors the default warehouse.
starrocks_fe_last_finished_job_timestamp
- Unit: ms
- Type: Instantaneous
- Description: Indicates the end time of the last query or loading under the specific warehouse. For a shared-nothing cluster, this item only monitors the default warehouse.
starrocks_fe_query_resource_group
- Unit: Count
- Type: Cumulative
- Description: Indicates the total number of queries executed under the specific resource group.
starrocks_fe_query_resource_group_err
- Unit: Count
- Type: Cumulative
- Description: Indicates the number of failed queries under the specific resource group.
starrocks_fe_query_resource_group_latency
- Unit: ms
- Type: Cumulative
- Description: Indicates the latency statistics for queries under the specific resource group.
starrocks_fe_tablet_num
- Unit: Count
- Type: Instantaneous
- Description: Indicates the number of tablets on each BE node.
starrocks_fe_tablet_max_compaction_score
- Unit: Count
- Type: Instantaneous
- Description: Indicates the highest Compaction Score on each BE node.
update_compaction_outputs_total
- Unit: Count
- Description: Total number of Primary Key table compactions.
update_del_vector_bytes_total
- Unit: Bytes
- Description: Total memory used for caching DELETE vectors in Primary Key tables.
push_request_duration_us
- Unit: us
- Description: Total time spent on Spark Load.
writable_blocks_total (Deprecated)
disks_data_used_capacity
- Description: Used capacity of each disk (represented by a storage path).
query_scan_rows
- Unit: Count
- Description: Total number of scanned rows.
update_primary_index_num
- Unit: Count
- Description: Number of Primary Key indexes cached in memory.
result_buffer_block_count
- Unit: Count
- Description: Number of blocks in the result buffer.
query_scan_bytes
- Unit: Bytes
- Description: Total number of scanned bytes.
disk_reads_completed
- Unit: Count
- Description: Number of successfully completed disk reads.
query_cache_hit_count
- Unit: Count
- Description: Number of query cache hits.
jemalloc_resident_bytes
- Unit: Bytes
- Description: Maximum number of bytes in physically resident data pages mapped by the allocator, comprising all pages dedicated to allocator metadata, pages backing active allocations, and unused dirty pages.
blocks_open_writing (Deprecated)
disk_io_time_weigthed
- Unit: ms
- Description: Weighted time spent on I/Os.
update_compaction_task_byte_per_second
- Unit: Bytes/s
- Description: Estimated rate of Primary Key table compactions.
blocks_open_reading (Deprecated)
tablet_update_max_compaction_score
- Unit: -
- Description: Highest compaction score of tablets in Primary Key tables in the current BE.
segment_read
- Unit: Count
- Description: Total number of segment reads.
disk_io_time_ms
- Unit: ms
- Description: Time spent on I/Os.
load_mem_bytes
- Unit: Bytes
- Description: Memory cost of data loading.
delta_column_group_get_non_pk_total
- Unit: Count
- Description: Total number of times to get delta column group (for non-Primary Key tables only).
query_scan_bytes_per_second
- Unit: Bytes/s
- Description: Estimated rate of scanned bytes per second.
active_scan_context_count
- Unit: Count
- Description: Total number of scan tasks created by Flink/Spark SQL.
fd_num_limit
- Unit: Count
- Description: Maximum number of file descriptors.
update_compaction_task_cost_time_ns
- Unit: ns
- Description: Total time spent on the Primary Key table compactions.
delta_column_group_get_hit_cache
- Unit: Count
- Description: Total number of delta column group cache hits (for Primary Key tables only).
data_stream_receiver_count
- Unit: Count
- Description: Cumulative number of instances serving as Exchange receivers in BE.
bytes_written_total
- Unit: Bytes
- Description: Total bytes written (sectors write * 512).
transaction_streaming_load_bytes
- Unit: Bytes
- Description: Total loading bytes of transaction load.
running_cumulative_compaction_task_num
- Unit: Count
- Description: Total number of running cumulative compactions.
transaction_streaming_load_requests_total
- Unit: Count
- Description: Total number of transaction load requests.
cpu
- Unit: -
- Description: CPU usage information returned by
/proc/stat
.
update_del_vector_num
- Unit: Count
- Description: Number of the DELETE vector cache items in Primary Key tables.
disks_avail_capacity
- Description: Available capacity of a specific disk.
clone_mem_bytes
- Unit: Bytes
- Description: Memory used for replica clone.
fragment_requests_total
- Unit: Count
- Description: Total fragment instances executing on a BE (for non-pipeline engine).
disk_write_time_ms
- Unit: ms
- Description: Time spent on disk writing. Unit: ms.
schema_change_mem_bytes
- Unit: Bytes
- Description: Memory used for Schema Change.
thrift_connections_total
- Unit: Count
- Description: Total number of thrift connections (including finished connections).
thrift_opened_clients
- Unit: Count
- Description: Number of currently opened thrift clients.
thrift_used_clients
- Unit: Count
- Description: Number of thrift clients in use currently.
thrift_current_connections (Deprecated)
disk_bytes_read
- Unit: Bytes
- Description: Total bytes read from the disk(sectors read * 512).
base_compaction_task_cost_time_ms
- Unit: ms
- Description: Total time spent on base compactions.
update_primary_index_bytes_total
- Unit: Bytes
- Description: Total memory cost of the Primary Key index.
compaction_deltas_total
- Unit: Count
- Description: Total number of merged rowsets from base compactions and cumulative compactions.
max_network_receive_bytes_rate
- Unit: Bytes
- Description: Total bytes received over the network (maximum value among all network interfaces).
max_network_send_bytes_rate
- Unit: Bytes
- Description: Total bytes sent over the network (maximum value among all network interfaces).
chunk_allocator_mem_bytes
- Unit: Bytes
- Description: Memory used by the chunk allocator.
query_cache_usage_ratio
- Unit: -
- Description: Current query cache usage ratio.
process_fd_num_limit_soft
- Unit: Count
- Description: Soft limit on the maximum number of file descriptors. Please note that this item indicates the soft limit. You can set the hard limit using the
ulimit
command.
query_cache_hit_ratio
- Unit: -
- Description: Hit ratio of query cache.
tablet_metadata_mem_bytes
- Unit: Bytes
- Description: Memory used by tablet metadata.
jemalloc_retained_bytes
- Unit: Bytes
- Description: Total bytes of virtual memory mappings that were retained rather than returned to the operating system via operations like munmap(2).
unused_rowsets_count
- Unit: Count
- Description: Total number of unused rowsets. Please note that these rowsets will be reclaimed later.
update_rowset_commit_apply_total
- Unit: Count
- Description: Total number of COMMIT and APPLY for Primary Key tables.
segment_zonemap_mem_bytes
- Unit: Bytes
- Description: Memory used by segment zonemap.
base_compaction_task_byte_per_second
- Unit: Bytes/s
- Description: Estimated rate of base compactions.
transaction_streaming_load_duration_ms
- Unit: ms
- Description: Total time spent on Stream Load transaction Interface.
memory_pool_bytes_total
- Unit: Bytes
- Description: Memory used by the memory pool.
short_key_index_mem_bytes
- Unit: Bytes
- Description: Memory used by the short key index.
disk_bytes_written
- Unit: Bytes
- Description: Total bytes written to disk.
segment_flush_queue_count
- Unit: Count
- Description: Number of queued tasks in the segment flush thread pool.
jemalloc_metadata_bytes
- Unit: Bytes
- Description: Total number of bytes dedicated to metadata, comprising base allocations used for bootstrap-sensitive allocator metadata structures and internal allocations. The usage of transparent huge pages is not included in this item.
network_send_bytes
- Unit: Bytes
- Description: Number of bytes sent over the network.
update_mem_bytes
- Unit: Bytes
- Description: Memory used by Primary Key table APPLY tasks and Primary Key index.
blocks_created_total (Deprecated)
query_cache_usage
- Unit: Bytes
- Description: Current query cache usages.
memtable_flush_duration_us
- Unit: us
- Description: Total time spent on memtable flush.
push_request_write_bytes
- Unit: Bytes
- Description: Total bytes written via Spark Load.
jemalloc_active_bytes
- Unit: Bytes
- Description: Total bytes in active pages allocated by the application.
load_rpc_threadpool_size
- Unit: Count
- Description: The current size of the RPC thread pool, which is used for handling Routine Load and loading via table functions. The default value is 10, with a maximum value of 1000. This value is dynamically adjusted based on the usage of the thread pool.
publish_version_queue_count
- Unit: Count
- Description: Queued task count in the Publish Version thread pool.
chunk_pool_system_free_count
- Unit: Count
- Description: Memory chunk allocation/cache metrics.
chunk_pool_system_free_cost_ns
- Unit: ns
- Description: Memory chunk allocation/cache metrics.
chunk_pool_system_alloc_count
- Unit: Count
- Description: Memory chunk allocation/cache metrics.
chunk_pool_system_alloc_cost_ns
- Unit: ns
- Description: Memory chunk allocation/cache metrics.
chunk_pool_local_core_alloc_count
- Unit: Count
- Description: Memory chunk allocation/cache metrics.
chunk_pool_other_core_alloc_count
- Unit: Count
- Description: Memory chunk allocation/cache metrics.
fragment_endpoint_count
- Unit: Count
- Description: Cumulative number of instances serving as Exchange senders in BE.
disk_sync_total (Deprecated)
max_disk_io_util_percent
- Unit: -
- Description: Maximum disk I/O utilization percentage.
network_receive_bytes
- Unit: Bytes
- Description: Total bytes received via network.
storage_page_cache_mem_bytes
- Unit: Bytes
- Description: Memory used by storage page cache.
jit_cache_mem_bytes
- Unit: Bytes
- Description: Memory used by jit compiled function cache.
column_partial_update_apply_total
- Unit: Count
- Description: Total number of APPLY for partial updates by column (Column mode)
disk_writes_completed
- Unit: Count
- Description: Total number of successfully completed disk writes.
memtable_flush_total
- Unit: Count
- Description: Total number of memtable flushes.
page_cache_hit_count
- Unit: Count
- Description: Total number of hits in the storage page cache.
bytes_read_total (Deprecated)
update_rowset_commit_request_total
- Unit: Count
- Description: Total number of rowset COMMIT requests in Primary Key tables.
tablet_cumulative_max_compaction_score
- Unit: -
- Description: Highest cumulative compaction score of tablets in this BE.
column_zonemap_index_mem_bytes
- Unit: Bytes
- Description: Memory used by column zonemaps.
push_request_write_bytes_per_second
- Unit: Bytes/s
- Description: Data writing rate of Spark Load.
process_thread_num
- Unit: Count
- Description: Total number of threads in this process.
query_cache_lookup_count
- Unit: Count
- Description: Total number of query cache lookups.
http_requests_total (Deprecated)
http_request_send_bytes (Deprecated)
cumulative_compaction_task_cost_time_ms
- Unit: ms
- Description: Total time spent on cumulative compactions.
column_metadata_mem_bytes
- Unit: Bytes
- Description: Memory used by column metadata.
plan_fragment_count
- Unit: Count
- Description: Number of currently running query plan fragments.
page_cache_lookup_count
- Unit: Count
- Description: Total number of storage page cache lookups.
query_mem_bytes
- Unit: Bytes
- Description: Memory used by queries.
load_channel_count
- Unit: Count
- Description: Total number of loading channels.
push_request_write_rows
- Unit: Count
- Description: Total rows written via Spark Load.
running_base_compaction_task_num
- Unit: Count
- Description: Total number of running base compaction tasks.
fragment_request_duration_us
- Unit: us
- Description: Cumulative execution time of fragment instances (for non-pipeline engine).
process_mem_bytes
- Unit: Bytes
- Description: Memory used by this process.
broker_count
- Unit: Count
- Description: Total number of filesystem brokers (by host address) created.
segment_replicate_queue_count
- Unit: Count
- Description: Queued task count in the Segment Replicate thread pool.
brpc_endpoint_stub_count
- Unit: Count
- Description: Total number of bRPC stubs (by address).
readable_blocks_total (Deprecated)
delta_column_group_get_non_pk_hit_cache
- Unit: Count
- Description: Total number of hits in the delta column group cache (for non-Primary Key tables).
update_del_vector_deletes_new
- Unit: Count
- Description: Total number of newly generated DELETE vectors used in Primary Key tables.
compaction_bytes_total
- Unit: Bytes
- Description: Total merged bytes from base compactions and cumulative compactions.
segment_metadata_mem_bytes
- Unit: Bytes
- Description: Memory used by segment metadata.
column_partial_update_apply_duration_us
- Unit: us
- Description: Total time spent on partial updates for columns' APPLY tasks (Column mode).
bloom_filter_index_mem_bytes
- Unit: Bytes
- Description: Memory used by Bloomfilter indexes.
routine_load_task_count
- Unit: Count
- Description: Number of currently running Routine Load tasks.
delta_column_group_get_total
- Unit: Count
- Description: Total number of times to get delta column groups (for Primary Key tables).
disk_read_time_ms
- Unit: ms
- Description: Time spent on reading from disk. Unit: ms.
update_compaction_outputs_bytes_total
- Unit: Bytes
- Description: Total bytes written by Primary Key table compactions.
memtable_flush_queue_count
- Unit: Count
- Description: Queued task count in the memtable flush thread pool.
query_cache_capacity
- Description: Capacity of query cache.
streaming_load_duration_ms
- Unit: ms
- Description: Total time spent on Stream Load.
streaming_load_current_processing
- Unit: Count
- Description: Number of currently running Stream Load tasks.
streaming_load_bytes
- Unit: Bytes
- Description: Total bytes loaded by Stream Load.
load_rows
- Unit: Count
- Description: Total loaded rows.
load_bytes
- Unit: Bytes
- Description: Total loaded bytes.
meta_request_total
- Unit: Count
- Description: Total number of meta read/write requests.
meta_request_duration
- Unit: us
- Description: Total meta read/write duration.
tablet_base_max_compaction_score
- Unit: -
- Description: Highest base compaction score of tablets in this BE.
page_cache_capacity
- Description: Capacity of the storage page cache.
cumulative_compaction_task_byte_per_second
- Unit: Bytes/s
- Description: Rate of bytes processed during cumulative compactions.
stream_load
- Unit: -
- Description: Total loaded rows and received bytes.
stream_load_pipe_count
- Unit: Count
- Description: Number of currently running Stream Load tasks.
binary_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the BINARY column pool.
int16_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the INT16 column pool.
decimal_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the DECIMAL column pool.
double_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the DOUBLE column pool.
int128_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the INT128 column pool.
date_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the DATE column pool.
int64_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the INT64 column pool.
int8_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the INT8 column pool.
datetime_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the DATETIME column pool.
int32_column_pool_bytes
- Unit: Bytes
- Description: Memory used by the INT32 column pool.