StarRocks-BE
标题 | 指标名称 | 指标单位 | 指标含义 |
COMPACTION DELTAS 数据量 | Cumulative | rowsets | Cumulative compaction deltas 的数据量 |
| Base | rowsets | Base compaction deltas 的数据量 |
| Update | rowsets | Update compaction deltas 的数据量 |
COMPACTION 数据量 | Cumulative | bytes | Cumulative compaction bytes 的数据量 |
| Base | bytes | Base compaction bytes 的数据量 |
| Update | bytes | Update compaction bytes 的数据量 |
TABLET COMPACTIO 最高分 | CumulativeMax | score | tablet 中最大的 base compaction score |
| BaseMax | score | tablet base 最大 compaction 分数 |
ENGINE 请求失败统计(1) | base_compaction | count | engine 失败请求,类型为 base_compaction 的数量 |
| clone | count | engine 失败请求,类型为 clonE 的数量 |
| create_rollup | count | engine 失败请求,类型为 create_rollup的数量 |
| create_tablet | count | engine 失败请求,类型为 create_tablet 的数量 |
| cumulative_compaction | count | engine 失败请求,类型为 cumulative_compaction 的数量 |
| delete | count | engine 失败请求,类型为 deletE 的数量 |
| finish_task | count | engine 失败请求,类型为 finish_task的数量 |
ENGINE 请求失败统计(2) | publish | count | engine 失败请求,类型为 publish的数量 |
| report_all_tablets | count | engine 失败请求,类型为 report_all_tablets的数量 |
| report_disk | count | engine 失败请求,类型为 report_disk的数量 |
| report_tablet | count | engine 失败请求,类型为 report_tablet 的数量 |
| report_task | count | engine 失败请求,类型为 report_task的数量 |
| schema_change | count | engine 失败请求,类型为 schema_changE 的数量 |
ENGINE 请求统计(1) | base_compaction | count | engine 失败请求,类型为 base_compaction 的数量 |
| clone | count | engine 失败请求,类型为 clonE 的数量 |
| create_rollup | count | engine 失败请求,类型为 create_rollup的数量 |
| create_tablet | count | engine 失败请求,类型为 create_tablet 的数量 |
| cumulative_compaction | count | engine 失败请求,类型为 cumulative_compaction 的数量 |
| delete | count | engine 失败请求,类型为 deletE 的数量 |
| drop_tablet | count | engine 失败请求,类型为 drop_tablet 的数量 |
| finish_task | count | engine 失败请求,类型为 finish_task的数量 |
ENGINE 请求统计(2) | publish | count | engine 失败请求,类型为 publish 的数量 |
| report_all_tablets | count | engine 失败请求,类型为 report_all_tablets的数量 |
| report_disk | count | engine 失败请求,类型为 report_disk的数量 |
| report_tablet | count | engine 失败请求,类型为 report_tablet 的数量 |
| report_task | count | engine 失败请求,类型为 report_task的数量 |
| schema_change | count | engine 失败请求,类型为 schema_changE 的数量 |
| storage_migrate | count | engine 失败请求,类型为 Storage_migratE 的数量 |
FRAGMENT 统计 | PlanFragment | count | plan fragment 数量 |
| Endpoint | count | DataStream 的数量 |
FRAGMENT 请求时间 | Duration | 微秒 | fragment 的请求时间 |
TXN 请求统计 | begin | count | txn 类型为 begin 的请求数量 |
| commit | count | txn 类型为 commit 的请求数量 |
| exec | count | txn 类型为 exec 的请求数量 |
| rollback | count | txn 类型为 rollback 的请求数量 |
STREAMING LOAD 数据量 | LoadTotal | bytes | stream load导入的数据大小 |
STREAMING LOAD 统计 | CurrentProcessing | count | streaming load 现有进程数 |
| PipeCount | count | streaming load Pipe数量 |
STREAMING LOAD 时间 | Duration | ms | streaming load 持续时间 |
BE 内存 | Total | bytes | BE memory pool大小 |
| Allocated | bytes | BE memory allocated 大小 |
进程文件句柄数 | Used | count | BE 进程使用文件句柄数量 |
| SoftLimit | count | BE 进程文件句柄 soft 限制数量 |
| HardLimit | count | BE 进程文件句柄 hard 限制数量 |
进程运行线程数 | Thread | count | BE 进程运行的线程个数 |
THRIFT 使用数量 | Broker | count | Broker 使用 thrift 的数量 |
| Backend | count | BE 使用 thrift 的数量 |
| Frontend | count | FE 使用 thrift 的数量 |
TABLET 写统计 | Writer | count | BE TABLET 写统计 |
TABLET COMPACTION 最高分 | UpdateMax | score | tablet update 最大compaction 分数 |
增删 vector 总字节量 | update_del_vector_bytes | byte | 增删 vector 总字节量 |
当前增删 vector 数量 | update_del_vector_num | count | 当前增删 vector 数量 |
更新主键索引总字节量 | update_primary_index_bytes | byte | 更新主键索引总字节量 |
更新主键索引数量 | update_primary_index_num | count | 更新主键索引数量 |
删除 vector 总数量 | vector_deletes_total | count | 删除 vector 总数量 |
更新 rowset 提交请求 | failed | count | 更新 rowset 提交失败请求量 |
| total | count | 更新 rowset 提交总请求量 |
更新 rowset 提交应用持续时间 | duration | us | 更新 rowset 提交应用持续时间 |
更新 rowset 提交应用总量 | total | count | 更新 rowset 提交应用总量 |
BE 内存分配统计(1) | chunk_allocator_mem | byte | chunk_allocator_mem 大小 |
| clone_mem | byte | clone_mem 大小 |
| column_pool_mem | byte | column_pool_mem 大小 |
| compaction_mem | byte | compaction_mem 大小 |
| consistency_mem | byte | consistency_mem 大小 |
| load_mem | byte | load_mem 大小 |
BE 内存分配统计(2) | query_mem | byte | query_mem 大小 |
| schema_change_mem | byte | schema_change_mem 大小 |
| storage_page_cache_mem | byte | storage_page_cache_mem 大小 |
| metadata_mem | byte | metadata_mem 大小 |
| update_mem | byte | update_mem 大小 |
pip 执行线程队列长度 | pip_exe_driver | byte | pip_exe_driver 队列长度 |
| pip_exe_poller_block | byte | pip_exe_poller_block 队列长度 |
| wg_pip_exe_driver | byte | wg_pip_exe_driver 队列长度 |
| wg_pip_exe_poller_block | byte | wg_pip_exe_poller_block 队列长度 |
扫描累计总行数 | rows | count | 扫描累计总行数 |
STREAM LOAD 数据量 | load_rows | count | load_rows 数据量 |
每秒扫描字节数 | query_scan_bytes | byte | 每秒扫描字节数 |
meta 请求次数 | write | count | 写 meta 请求次数 |
| read | count | 读 meta 请求次数 |
meta 请求时长 | write | us | 写 meta 请求时长 |
| read | us | 读 meta 请求时长 |
请求推送次数 | success | count | 成功请求推送次数 |
| fail | count | 失败请求推送次数 |
磁盘使用量(disks data used capacity) | used_capacity | byte | 磁盘使用量 |
磁盘状态(disks state) | disks_state | 1:正常 0:异常 | 磁盘状态 |
内存统计 | process | Bytes | process 内存占用 |
| datacache | Bytes | datacache 内存占用 |
| jit_cache | Bytes | jit cache 内存占用 |
Metadata 内存统计 | tablet | Bytes | tablet metadata 内存占用 |
| rowset | Bytes | rowset metadata 内存占用 |
| segment | Bytes | segment metadata 内存占用 |
| column | Bytes | column metadata 内存占用 |
Tablet Metadata 内存统计 | tablet_schema | Bytes | tablet schema 内存占用 |
Segment Metadata 内存统计 | segment_zonemap | Bytes | segment zonemap 内存占用 |
| short_key_index | Bytes | short key index 内存占用 |
Column Metadata 内存统计 | bitmap_index | Bytes | bitmap cache 内存占用 |
| bf_index | Bytes | bloom fliter index cache 内存占用 |
| zonemap_index | Bytes | column zonemap cache 内存占用 |
| ordinal_index | Bytes | oridinal index cache 内存占用 |
Column Pool 内存统计 | binary | Bytes | binary column pool 内存占用 |
| uint8 | Bytes | uint8 column pool 内存占用 |
| int8 | Bytes | int8 column pool 内存占用 |
| int16 | Bytes | int16 column pool 内存占用 |
| int32 | Bytes | int32 column pool 内存占用 |
| int64 | Bytes | int64 column pool 内存占用 |
| int128 | Bytes | int128 column pool 内存占用 |
| float | Bytes | float column pool 内存占用 |
| double | Bytes | double column pool 内存占用 |
| decimal | Bytes | decimal column pool 内存占用 |
| date | Bytes | date column pool 内存占用 |
| datetime | Bytes | datetime column pool 内存占用 |
Result Block | block_count | Count | 结果缓存中的 Block 数 |
| queue_count | Count | 结果 Block 队列中的结果数量 |
Publish 延迟 | publish_latency | ms | publish 延迟 |
Publish QPS | publish_qps | Count/s | publish QPS |
数据回收QPS | move_trash_qps | Count/s | 数据回收的QPS |
数据回收延迟 | latency_avg | ms | 数据回收的平均延迟 |
| latency_80 | ms | 数据回收的80分位延迟 |
| latency_99 | ms | 数据回收的99分位延迟 |
Rowset 数量 | unused | Count | 未使用的 rowset 的总数 |
| in_use | Count | 正在使用的rowset数量 |
获取Delta Column Group 统计 | get_non_pk | Count | 获取非主键表 delta column group 的次数 |
| get_pk | Count | 获取主键表 delta column group 的次数 |
命中Delta Column Group Cache统计 | non_pk_hit | Count | 非主键表中 delta column group 缓存的命中次数 |
| pk_hit | Count | 主键表中 delta column group 缓存的命中次数 |
Partial Update Apply 耗时 | duration | us | 列的 Partial Update(列模式)的 APPLY 任务的时间 |
Partial Update Apply 次数 | count | Count | 列的 Partial Update (列模式)的 APPLY 的数量 |
Delta Writer 等待耗时 | wait_replica | us | delta writer 等待replica同步耗时 |
| wait_writer | us | delta writer 等待flush同步耗时 |
打开Segment次数 | open_segments | Count | 每分钟打开的segment次数 |
| open_segments_io | Count | 每分钟打开segment生成IO任务的次数 |
Stream Load 请求 | requests | Count | 每秒Stream Load 请求的次数 |
Transaction Stream Load 导入数据量 | load_bytes | Bytes | 通过 Stream Load 事务接口导入的字节数 |
Transaction Stream Load 导入耗时 | load_duration | ms | 事务导入的时间 |
Transaction Stream Load 任务数量 | current_processing | Count | 当前运行的 Transaction Stream Load 任务数量 |
Transaction Stream Load 请求 | load_requests | Count | 每秒Transaction Stream Load 请求的次数 |
Memtable Flush 次数 | flush_count | Count/s | Memtable Flush 的次数 |
Memtable Flush 大小 | flush_memory | Bytes | Memtable Flush memory数据大小 |
| flush_disk | Bytes | Memtable Flush disk数据大小 |
Memtable Flush 耗时 | flush_io | us | Memtable Flush IO耗时 |
| flush_duration | us | Memtable Flush 耗时 |
| finalize_duration | us | Memtable Flush finalize耗时 |
Segment Flush 大小 | flush_bytes | Bytes | Segment Flush 数据大小 |
Segment Flush 次数 | flush_count | Count/s | Segment Flush 次数 |
Segment Flush 耗时 | flush_duration | us | Segment Flush 耗时 |
| flush_io_duration | us | Segment Flush IO耗时 |
主键表Compaction的数量 | outputs_count | Count/s | 主键表Compaction的数量 |
主键表Compaction写入数据量 | outputs_bytes | Bytes | 主键表 Compaction 时写入的字节数 |
主键表Compaction耗时 | duration | us | 主键表 Compaction 任务的耗时 |
Routine Load任务数 | tasks | Count | 运行的 Routine Load 任务的数量 |
Spark Load 写入速率 | write_bytes | Bytes/s | Spark Load 的写入速率 |
Tablet 最大rowset数量 | rowset_nums | Count | tablet中最大rowset数 |
Load RPC 线程池大小 | size | Count | Load RPC 线程池大小 |
Load Channel 数量 | count | Count | Load Channel 数量 |
Add Chunks 耗时 | duration | us | add chunks 耗时 |
| wait_memtable | us | add chunks 等待memtable耗时 |
| wait_replica | us | add chunks 等待replica耗时 |
| wait_writer | us | add chunks 等待写入耗时 |
Add Chunks 次数 | count | Count/s | add chunks 次数 |
fragment request 次数 | count | Count/s | Fragment 实例的累积执行次数(非 Pipeline Engine ) |
导入数据量 | load_bytes | Bytes | 总导入字节数 |
导入行数 | load_rows | Count | 总导入行数 |
Async Delta Writer 执行次数 | async_delta_writer | Count | async delta writer 执行次数 |
Async Delta Writer Task 执行耗时 | execute | us | async delta writer task 执行时间 |
| pending | us | async delta writer task 等待时间 |
Async Delta Writer Task 执行次数 | count | Count | async delta writer task 执行次数 |
Update Apply 线程池耗时 | pending_time | ns | update apply 线程池排队时间 |
| execute_time | ns | update apply 线程池执行任务时长 |
Update Apply 线程池任务 | executed_tasks | Count/s | update apply 线程池已执行任务个数 |
| queue_count | Count | update apply 线程池排队任务数量 |
Update Apply 线程池大小 | active_threads | Count | update apply 线程池中active线程个数 |
| running_threads | Count | update apply 线程池中存活的线程个数 |
| threadpool_size | Count | update apply 线程池大小 |
Segment Replicate 线程池耗时 | pending_time | ns | segment replicate 线程池排队时间 |
| execute_time | ns | segment replicate 线程池执行任务时长 |
Segment Replicate 线程池任务 | executed_tasks | Count/s | segment replicate 线程池已执行任务个数 |
| queue_count | Count | segment replicate 线程池排队任务数量 |
Segment Replicate 线程池大小 | active_threads | Count | segment replicate 线程池中active线程个数 |
| running_threads | Count | segment replicate 线程池中存活的线程个数 |
| threadpool_size | Count | segment replicate 线程池大小 |
Segment Flush 线程池耗时 | pending_time | ns | segment flush 线程池排队时间 |
| execute_time | ns | segment flush 线程池执行任务时长 |
Segment Flush 线程池任务 | executed_tasks | Count/s | segment flush 线程池已执行任务个数 |
| queue_count | Count | segment flush 线程池排队任务数量 |
Segment Flush 线程池大小 | active_threads | Count | segment flush 线程池中active线程个数 |
| running_threads | Count | segment flush 线程池中存活的线程个数 |
| threadpool_size | Count | segment flush 线程池大小 |
Publish Version 线程池耗时 | pending_time | ns | publish version 线程池排队时间 |
| execute_time | ns | publish version 线程池执行任务时长 |
Publish Version 线程池任务 | executed_tasks | Count/s | publish version 线程池已执行任务个数 |
| queue_count | Count | publish version 线程池排队任务数量 |
Publish Version 线程池大小 | active_threads | Count | publish version 线程池中active线程个数 |
| running_threads | Count | publish version 线程池中存活的线程个数 |
| threadpool_size | Count | publish version 线程池大小 |
Primary Index Compaction 线程池耗时 | pending_time | ns | primary index compaction 线程池排队时间 |
| execute_time | ns | primary index compaction 线程池执行任务时长 |
Primary Index Compaction 线程池任务 | executed_tasks | Count/s | primary index compaction 线程池已执行任务个数 |
| queue_count | Count | primary index compaction 线程池排队任务数量 |
Primary Index Compaction 线程池大小 | active_threads | Count | primary index compaction 线程池中active线程个数 |
| running_threads | Count | primary index compaction 线程池中存活的线程个数 |
| threadpool_size | Count | primary index compaction 线程池大小 |
Memtable Flush 线程池耗时 | pending_time | ns | memtable flush 线程池排队时间 |
| execute_time | ns | memtable flush 线程池执行任务时长 |
Memtable Flush 线程池任务 | executed_tasks | Count/s | memtable flush 线程池已执行任务个数 |
| queue_count | Count | memtable flush 线程池排队任务数量 |
Memtable Flush 线程池大小 | active_threads | Count | memtable flush 线程池中active线程个数 |
| running_threads | Count | memtable flush 线程池中存活的线程个数 |
| threadpool_size | Count | memtable flush 线程池大小 |
Lake Memtable Flush 线程池耗时 | pending_time | ns | lake memtable flush 线程池排队时间 |
| execute_time | ns | lake memtable flush 线程池执行任务时长 |
Lake Memtable Flush 线程池任务 | executed_tasks | Count/s | lake memtable flush 线程池已执行任务个数 |
| queue_count | Count | lake memtable flush 线程池排队任务数量 |
Lake Memtable Flush 线程池大小 | active_threads | Count | lake memtable flush 线程池中active线程个数 |
| running_threads | Count | lake memtable flush 线程池中存活的线程个数 |
| threadpool_size | Count | lake memtable flush 线程池大小 |
Async Delta Writer 线程池耗时 | pending_time | ns | async delta writer 线程池排队时间 |
| execute_time | ns | async delta writer 线程池执行任务时长 |
Async Delta Writer 线程池任务 | executed_tasks | Count/s | async delta writer 线程池已执行任务个数 |
| queue_count | Count | async delta writer 线程池排队任务数量 |
Async Delta Writer 线程池大小 | active_threads | Count | async delta writer 线程池中active线程个数 |
| running_threads | Count | async delta writer 线程池中存活的线程个数 |
| threadpool_size | Count | async delta writer 线程池大小 |
主键表中新生成的 DELETE 向量的总数 | new_delete_vector | Count | 主键表中新生成的 DELETE 向量的总数 |
Query Cache 使用率 | usage_ratio | % | query cache 使用率 |
Query Cache 大小 | capacity | Bytes | query cache 容量 |
| usage | Bytes | query cache 使用量 |
Query Cache 命中率 | hit_ratio | % | query cache 命中率 |
Query Cache 次数 | lookup | Count | query cache 查询次数 |
| hit | Count | query cache 命中次数 |
Page Cache次数 | lookup | Count | page cache 查询次数 |
| hit | Count | page cache 命中次数 |
Page Cache 容量 | capacity | Bytes | page cache 容量 |
Meta 请求耗时 | read | us | 元数据读的持续时间 |
| write | us | 元数据写的持续时间 |
Meta 请求次数 | read | Count | 元数据读请求的数量 |
| write | Count | 元数据写请求的数量 |
Brpc endpoint stub 个数 | count | Count | bRPC Stub 的总数(按主机地址计) |
Pipeline Driver 耗时 | driver_execution_time | ns | PipelineDriver Executor 处理 PipelineDriver 所用的时间 |
Pipeline 统计 | query_ctx_cnt | Count | 正在运行的查询的总数 |
| driver_queue_len | Count | 当前在 BE 中等待调度的 Ready Driver 的数量 |
| driver_schedule_count | Count | BE 中 Pipeline Executor 的 Driver 调度次数 |
| pipe_drivers | Count | 当前BE的总driver数 |
| poller_block_queue_len | Count | PipelineDriverPoller 的 Block 队列的当前长度 |
| perpare_pool_queue_len | Count | Pipeline Prepare 线程池中排队的任务数量 |
| scan_executor_queuing | Count | 当前由 Scan Operator 发起待执行的异步 I/O 任务的数量 |
PID | pid | None | 进程ID |
进程CPU使用率 | usage | % | CPU使用率 |
| system_usage | % | system CPU使用率 |
| user_usage | % | user CPU使用率 |
磁盘使用统计 | read | Bytes/s | 每秒磁盘读取字节数 |
| write | Bytes/s | 每秒磁盘写入字节数 |
进程FD统计 | fd_count | Count | 进程使用文件描述符的数量 |
线程总数 | thread_count | Count | 线程数量 |
进程启动时间 | uptime | s | 进程存活时间 |
最大磁盘IO使用率 | io_util | % | 最大磁盘使用百分比 |
Jemalloc 内存 | allocated | Bytes | Jemalloc分配的字节数 |
be磁盘IO时间 | io_time | ms | IO操作时间 |
be资源组CPU | in_use_cores | Count | 每个资源组当前正在使用的 CPU 核心的估计数量 |
be资源组超限 | overflow_count | Count | 每个资源组触发并发限制的查询数量(瞬时值) |
be资源组查询 | bigquery_count | Count | 每个资源组触发大查询限制的查询数量(瞬时值) |
be网络发送统计 | send | Bytes/s | 网络发送字节数 |
| receive | Bytes/s | 网络接受字节数 |
CPU利用率 | ProcessCpuLoad | % | CPU利用率 |
GC次数 | YGC | Count | Young GC 次数 |
| FGC | Count | Full GC 次数 |
GC时间 | FGCT | s | Full GC 消耗时间 |
| GCT | s | 垃圾回收时间消耗 |
| YGCT | s | Young GC 消耗时间 |
内存区域占比 | S0 | % | Survivor 0区内存使用占比 |
| E | % | Eden 区内存使用占比 |
| CCS | % | Compressed class space 区内存使用占比 |
| S1 | % | Survivor 1区内存使用占比 |
| O | % | Old 区内存使用占比 |
| M | % | Metaspace 区内存使用占比 |
JVM内存 | MemHeapUsedM | MBytes | 已使用的堆内存 |
| MemNonHeapUsedM | MBytes | 已使用的堆外内存 |
| MemHeapCommittedM | MBytes | 已提交的堆内存 |
| MemNonHeapCommittedM | MBytes | 已提交的堆外内存 |
| MemHeapMaxM | MBytes | 最大堆内存 |
| MemHeapInitM | MBytes | 初始堆内存 |
| MemNonHeapInitM | MBytes | 初始堆外内存 |
文件句柄数 | MaxFileDescriptorCount | Count | 最大文件描述符数 |
| OpenFileDescriptorCount | Count | 打开文件描述符数 |
JVM线程数量 | PeakThreadCount | Count | 峰值线程数 |
| ThreadCount | Count | 总线程数量 |
| DaemonThreadCount | Count | Daemon线程数量 |
StarRocks-FE
标题 | 指标名称 | 指标单位 | 指标含义 |
ALTER 任务统计 | RollupRunning | count | 运行中的 alter job,类型为 ROLLUP 的数量 |
| SchemaChangeRunning | count | 运行中的 alter job,类型为 SCHEMA_CHANGE 的数量 |
IMAGE 统计 | Write | count | FE image write 的数量 |
| Push | count | FE image push 的数量 |
SCHEDULED_TABLET 数量 | ScheduledTablet | count | FE 中 scheduled tablet 数量 |
TRANSACTION 状态统计 | Reject | count | FE 被拒绝的 transaction 数量 |
| Begin | count | FE 开始 的 transaction 数量 |
| Success | count | FE 成功 的 transaction 数量 |
| Failed | count | FE 失败 的 transaction 数量 |
JVM 内存_HEAP | max | bytes | 最大 heap 内存 |
| committed | bytes | 已提交 heap 内存 |
| used | bytes | 已使用 heap 内存 |
JVM 内存_NONHEAP | committed | bytes | 已提交 non heap 内存 |
| used | bytes | 已使用 non heap 内存 |
JVM 内存_OLD | used | bytes | 已使用 old 内存 |
| peak_used | bytes | 最大使用 old 内存 |
| max | bytes | 最大 old 内存 |
JVM 内存_YOUNG | used | bytes | 已使用 young 内存 |
| peak_used | bytes | 最大使用 young 内存 |
| max | bytes | 最大 young 内存 |
ROUTINE LOAD QUEUE 大小 | report queue | count | FE report queuE 的大小 |
ROUTINE_LOAD 行数 | TotalRows | count | FE routine load 的行数 |
| ErrorRows | count | FE routine load 错误的行数 |
ROUTINE LOAD 大小 | Receive | bytes | FE routine load 的大小 |
TABLET_COMPACTION 最高分 | MAX | score | FE tablet 进行 compaction 时 compaction score 最大值 |
EDITLOG 写延时 | Quantile75 | ms | FE editlog 写延时的75分位数 |
| Quantile95 | ms | FE editlog写延时的95分位数 |
| Quantile98 | ms | FE editlog写延时的98分位数 |
| Quantile99 | ms | FE editlog写延时的99分位数 |
| Quantile999 | ms | FE editlog写延时的99.9分位数 |
GC 次数 | YoungGC | count | FE 节点 JVM Young GC 次数 |
| OldGC | count | FE 节点 JVM Old GC 次数 |
GC 时间 | YoungGC | ms | FE 节点 JVM Young GC 时间 |
| OldGC | ms | FE 节点 JVM Old GC 时间 |
JVM 线程数 | Total | count | FE 节点 JVM 中线程总数 |
| Peak | count | FE 节点 JVM 线程峰值 |
BROKER_LOAD 任务统计 | UNKNOWN | count | 类型为 BROKER,状态为 UNKNOWN 的 load job 数量 |
| PENDING | count | 类型为 BROKER,状态为 pENDING 的 load job 数量 |
| ETL | count | 类型为 BROKER,状态为 eTL 的 load job 数量 |
| LOADING | count | 类型为 BROKER,状态为 LOADING 的 load job 数量 |
| COMMITTED | count | 类型为 BROKER,状态为 cOMMITTED 的 load job 数量 |
| FINISHED | count | 类型为 BROKER,状态为 fINISHED 的 load job 数量 |
| CANCELLED | count | 类型为 BROKER,状态为 cANCELLED 的 load job 数量 |
DELETE_LOAD 任务统计 | UNKNOWN | count | 类型为 DELETE,状态为 UNKNOWN 的 load job 数量 |
| PENDING | count | 类型为 DELETE,状态为 pENDING 的 load job 数量 |
| ETL | count | 类型为 DELETE,状态为 eTL 的 load job 数量 |
| LOADING | count | 类型为 DELETE,状态为 LOADING 的 load job 数量 |
| COMMITTED | count | 类型为 DELETE,状态为 cOMMITTED 的 load job 数量 |
| FINISHED | count | 类型为 DELETE,状态为 fINISHED 的 load job 数量 |
| CANCELLED | count | 类型为 DELETE,状态为 cANCELLED 的 load job 数量 |
HADOOP_LOAD 任务统计 | UNKNOWN | count | 类型为 HADOOP,状态为 UNKNOWN 的 load job 数量 |
| PENDING | count | 类型为 HADOOP,状态为 pENDING 的 load job 数量 |
| ETL | count | 类型为 HADOOP,状态为 eTL 的 load job 数量 |
| LOADING | count | 类型为 HADOOP,状态为 LOADING 的 load job 数量 |
| COMMITTED | count | 类型为 HADOOP,状态为 cOMMITTED 的 load job 数量 |
| FINISHED | count | 类型为 HADOOP,状态为 fINISHED 的 load job 数量 |
| CANCELLED | count | 类型为 HADOOP,状态为 cANCELLED 的 load job 数量 |
INSERT_LOAD 任务统计 | UNKNOWN | count | 类型为 INSERT,状态为 UNKNOWN 的 load job 数量 |
| PENDING | count | 类型为 INSERT,状态为 pENDING 的 load job 数量 |
| ETL | count | 类型为 INSERT,状态为 eTL 的 load job 数量 |
| LOADING | count | 类型为 INSERT,状态为 LOADING 的 load job 数量 |
| COMMITTED | count | 类型为 INSERT,状态为 cOMMITTED 的 load job 数量 |
| FINISHED | count | 类型为 INSERT,状态为 fINISHED 的 load job 数量 |
| CANCELLED | count | 类型为 INSERT,状态为 cANCELLED 的 load job 数量 |
ROUTINE_LOAD 任务统计 | NEED_SCHEDULE | count | routine load jobs 统计,state=NEED_SCHEDULE |
| RUNNING | count | routine load jobs 统计,state=RUNNING |
| PAUSED | count | routine load jobs 统计,state=PAUSED |
| STOPPED | count | routine load jobs 统计,state=STOPPED |
| CANCELLED | count | routine load jobs 统计,state=CANCELLED |
SPARK_LOAD 任务统计 | UNKNOWN | count | 类型为 SPARK,状态为 UNKNOWN 的 load job 数量 |
| PENDING | count | 类型为 SPARK,状态为 pENDING 的 load job 数量 |
| ETL | count | 类型为 SPARK,状态为 eTL 的 load job 数量 |
| LOADING | count | 类型为 SPARK,状态为 LOADING 的 load job 数量 |
| COMMITTED | count | 类型为 SPARK,状态为 cOMMITTED 的 load job 数量 |
| FINISHED | count | 类型为 SPARK,状态为 fINISHED 的 load job 数量 |
| CANCELLED | count | 类型为 SPARK,状态为 cANCELLED 的 load job 数量 |
FE MASTER | FE Master | count | 是否为 FE Master;1 Master, 0 Fellower |
节点信息 | FeNodeNum | count | FE 总节点数 |
| BeNodeNum | count | BE 总节点数 |
| BeAliveNum | count | BE 活动节点数 |
| BeDecommissionedNum | count | BE 活动节点数 |
| BkDeadNum | count | Broker 死亡节点数 |
请求响应 | QPS | count/s | 每秒查询率 |
| RPS | count/s | 每秒能处理的请求数目 |
FE 查询统计 | total | count | FE 查询总数 |
| err | count | FE 查询错误总数 |
| timeout | count | FE 查询超时数 |
| success | count | FE 查询成功总数 |
| slow | count | FE 慢查询总数 |
查询失败率 | ErrRate | % | 查询错误率 |
FE 查询延时 | Quantile75 | ms | FE 查询延时的75分位数 |
| Quantile95 | ms | FE 查询延时的95分位数 |
| Quantile99 | ms | FE 查询延时的99分位数 |
| Quantile999 | ms | FE 查询延时的99.9分位数 |
CONNECTION 数量 | Num | count | FE 节点 connection 数量 |
最大 journal id | id | count | 最大 journal id |
Edit Log 写入次数 | write | count | Edit Log 写入次数 |
StarRocks-Broker
标题 | 指标名称 | 指标单位 | 指标含义 |
CPU 利用率 | ProcessCpuLoad | % | 进程 CPU 利用率 |
CPU 使用时间 | ProcessCpuTime | ms | CPU 累计使用时间 |
GC 次数 | YGC | 次 | Young GC 次数 |
| FGC | 次 | Full GC 次数 |
GC 时间 | GCT | s | 垃圾回收时间消耗 |
| FGCT | s | Full GC 消耗时间 |
| YGCT | s | Young GC 消耗时间 |
内存区域占比 | O | % | Old 区内存使用占比 |
| M | % | Metaspace 区内存使用占比 |
| CCS | % | Compressed class space 区内存使用占比 |
| S0 | % | Survivor 0区内存使用占比 |
| S1 | % | Survivor 1区内存使用占比 |
| E | % | Eden 区内存使用占比 |
JVM 内存 | MemHeapInitM | MB | JVM 初始 HeapMemory的数量 |
| MemNonHeapInitM | MB | JVM 初始 NonHeapMemory 的数量 |
| MemHeapMaxM | MB | JVM 配置的 HeapMemory 的数量 |
| MemHeapCommittedM | MB | JVM 当前已经提交的 HeapMemory 的数量 |
| MemHeapUsedM | MB | JVM 当前已经使用的 HeapMemory 的数量 |
| MemNonHeapCommittedM | MB | JVM 当前已经提交的 NonHeapMemory 的数量 |
| MemNonHeapUsedM | MB | JVM 当前已经使用的 NonHeapMemory 的数量 |
文件句柄数 | OpenFileDescriptorCount | count | 已打开文件描述符数 |
| MaxFileDescriptorCount | count | 最大文件描述符数 |
进程运行时间 | Uptime | s | 进程运行时间 |
工作线程数 | PeakThreadCount | count | 峰值线程数 |
| ThreadCount | count | 总线程数量 |
| DaemonThreadCount | count | Daemon 线程数量 |
StarRocks-CN
标题 | 指标名称 | 指标单位 | 指标含义 |
Publish Version QPS | qps | Count/s | publish version 每秒执行次数 |
Publish Version 延迟 | latency_avg | us | publish version平均延迟 |
| latency_80 | us | publish version80分位延迟 |
| latency_90 | us | publish version90分位延迟 |
| queuing_latency_avg | us | publish version任务排队的平均延迟 |
Publish Version 任务 | queued_tasks | Count | publish version排队任务数 |
| active_tasks | Count | publish version活跃任务数 |
Get Tablet Metadata QPS | qps | Count/s | get tablet metadata每秒执行次数 |
Get Tablet Metadata 延迟 | latency_avg | us | get tablet metadata平均延迟 |
| latency_80 | us | get tablet metadata80分位延迟 |
| latency_90 | us | get tablet metadata90分位延迟 |
Get Txn Log QPS | qps | Count/s | get txn log每秒执行次数 |
Get Txn Log 延迟 | latency_99 | us | get txn log99分位延迟 |
| latency_avg | us | get txn log平均延迟 |
Put Txn Log QPS | qps | Count/s | put txn log每秒执行次数 |
Put Txn Log 延迟 | latency_99 | us | put txn log99分位延迟 |
| latency_avg | us | put txn log平均延迟 |
Metadata Cache | usage | Bytes | metadata cache使用量 |
| capacity | Bytes | metadata cache容量 |
Schema Cache | hit | Count/min | schema cache 每分钟命中次数 |
| miss | Count/min | schema cache 每分钟未命中次数 |
Delvec Cache | hit | Count/min | delvec cache 每分钟命中次数 |
| miss | Count/min | delvec cache 每分钟未命中次数 |
Metadata Cache Hit Or Miss | hit | Count/min | metadata cache 每分钟命中次数 |
| miss | Count/min | metadata cache 每分钟未命中次数 |
Txn Log Cache Hit Or Miss | hit | Count/min | txn log cache 每分钟命中次数 |
| miss | Count/min | txn log cache 每分钟未命中次数 |
Segment Cache Hit Or Miss | hit | Count/min | segment cache 每分钟命中次数 |
| miss | Count/min | segment cache 每分钟未命中次数 |
Vacuum 线程池任务 | active_tasks | Count | vacuum 线程池活跃任务数 |
| queued_tasks | Count | vacuum 线程池排队任务数 |
DeleteFile 线程池任务 | active_tasks | Count | deletefile 线程池活跃任务数 |
| queued_tasks | Count | deletefile 线程池排队任务数 |
Vacuum Del File 延迟 | latency_avg | us | vacuum 删除文件平均延迟 |
| latency_80 | us | vacuum 删除文件80分位延迟 |
| latency_99 | us | vacuum 删除文件99分位延迟 |
Vacuum Del File QPS | qps | Count/s | vacuum 删除文件每秒执行次数 |
Vacuum Del File 失败次数 | fails | Count | vacuum 删除文件失败次数 |
Vacuum Delete Txnlog延迟 | latency_avg | us | vacuum 删除txnlog平均延迟 |
| latency_80 | us | vacuum 删除txnlog80分位延迟 |
| latency_99 | us | vacuum 删除txnlog99分位延迟 |
Vacuum Delete Txnlog QPS | qps | Count/s | vacuum 删除txnlog每秒执行次数 |
Metadata Travel 延迟 | latency_avg | us | metadata travel平均延迟 |
| latency_80 | us | metadata travel80分位延迟 |
| latency_99 | us | metadata travel99分位延迟 |
Metadata Travel QPS | qps | Count/s | metadata travel每秒执行次数 |
加载主键索引延迟 | latency_avg | us | 加载主键索引平均延迟 |
| latency_80 | us | 加载主键索引80分位延迟 |
| latency_99 | us | 加载主键索引99分位延迟 |
加载主键索引QPS | qps | Count/s | 加载主键索引每秒执行次数 |
HDFS 读取分位次数 | le16000 | Count | HDFS 读取时间小于16ms的次数 |
| le32000 | Count | HDFS 读取时间小于32ms的次数 |
| le64000 | Count | HDFS 读取时间小于64ms的次数 |
| total | Count | HDFS 读取次数 |
CACHEFS 读取分位次数 | le200 | Count | CACHEFS 读取时间小于200us的次数 |
| le3200 | Count | CACHEFS 读取时间小于3200us的次数 |
| le12800 | Count | CACHEFS 读取时间小于12800us的次数 |
| total | Count | CACHEFS 读取次数 |
HDFS 读取大小分位次数 | le8192 | Count | HDFS 读取小于8192字节的次数 |
| le65536 | Count | HDFS 读取小于65536字节的次数 |
| le262144 | Count | HDFS 读取小于262144字节的次数 |
| le4194304 | Count | HDFS 读取小于4194304字节的次数 |
| total | Count | HDFS 读取次数 |
CACHEFS 读取大小分位次数 | le8192 | Count | CACHEFS 读取小于8192字节的次数 |
| le65536 | Count | CACHEFS 读取小于65536字节的次数 |
| le262144 | Count | CACHEFS 读取小于262144字节的次数 |
| le4194304 | Count | CACHEFS 读取小于4194304字节的次数 |
| total | Count | CACHEFS 读取次数 |
FSLIB 读取吞吐 | hdfs | Bytes/s | HDFS 每秒读取吞吐 |
| cachefs | Bytes/s | CACHEFS 每秒读取吞吐 |
HDFS 写入分位次数 | le500 | Count | HDFS 写入时间小于500 us的次数 |
| le4000 | Count | HDFS 写入时间小于4 ms的次数 |
| le16000 | Count | HDFS 写入时间小于16 ms的次数 |
| le64000 | Count | HDFS 写入时间小于64 ms的次数 |
| total | Count | HDFS 写入次数 |
CACHEFS 写入分位次数 | le200 | Count | CACHEFS 写入时间小于200 us的次数 |
| le3200 | Count | CACHEFS 写入时间小于3200 us的次数 |
| le12800 | Count | CACHEFS 写入时间小于12800 us的次数 |
| total | Count | CACHEFS 写入次数 |
HDFS 写入大小分位次数 | le8192 | Count | HDFS 写入小于8192字节的次数 |
| le65536 | Count | HDFS 写入小于65536字节的次数 |
| le262144 | Count | HDFS 写入小于262144字节的次数 |
| le4194304 | Count | HDFS 写入小于4194304字节的次数 |
| total | Count | HDFS 写入次数 |
CACHEFS 写入大小分位次数 | le8192 | Count | CACHEFS 写入小于8192字节的次数 |
| le65536 | Count | CACHEFS 写入小于65536字节的次数 |
| le262144 | Count | CACHEFS 写入小于262144字节的次数 |
| le4194304 | Count | CACHEFS 写入小于4194304字节的次数 |
| total | Count | CACHEFS 写入次数 |
FSLIB 写入吞吐 | hdfs | Bytes/s | HDFS 每秒写入吞吐 |
| cachefs | Bytes/s | CACHEFS 每秒写入吞吐 |
FSLIB Cache Hit Or Miss | hits | Count/s | CACHEFS 缓存命中次数 |
| misses | Count/s | CACHEFS 缓存未命中次数 |
FSLIB Cache 大小 | meta_memory_size | Bytes | FSLIB starcache元数据占用内存大小 |
| data_memory_size | Bytes | FSLIB starcache 数据占用内存大小 |
| data_disk_size | Bytes | FSLIB starcache 数据占用磁盘大小 |
FS实例个数 | fs_instances | Count | FSLIB 当前FS实例个数 |
FSLIB 打开的文件数 | hdfs | Count | FSLIB 打开的HDFS文件次数 |
| cachefs | Count | FSLIB 打开的CACHEFS文件次数 |
FSLIB 创建的文件数 | hdfs | Count/s | FSLIB 每秒创建的HDFS文件个数 |
| cachefs | Count/s | FSLIB 每秒创建的CACHEFS文件个数 |
FSLIB List | hdfs | Count/s | FSLIB 每秒List HDFS文件次数 |
| cachefs | Count/s | FSLIB 每秒List CACHEFS文件次数 |
| posix | Count/s | FSLIB 每秒List POSIX文件次数 |
FSLIB List 耗时 | hdfs | us | FSLIB 每秒List HDFS延迟 |
FSLIB List 次数 | hdfs | Count/s | FSLIB 每秒List HDFS次数 |
FSLIB Delete Files 分位延迟 | le64000 | Count | FSLIB delete files 时长小于64ms的次数 |
| total | Count | FSLIB delete files 次数 |
FSLIB Delete Files 每秒平均耗时 | hdfs | us | FSLIB delete files HDFS 每秒平均耗时 |
FSLIB Delete File 次数 | le64000 | Count | FSLIB delete file 时长小于64ms的次数 |
| total | Count | FSLIB delete file 次数 |
FSLIB Delete File 每秒平均耗时 | hdfs | us | FSLIB delete file HDFS 每秒平均耗时 |
FSLIB Delete Dir 次数 | le64000 | Count | FSLIB delete dir 时长小于64ms的次数 |
| total | Count | FSLIB delete dir 次数 |
FSLIB Delete Dir 每秒平均耗时 | hdfs | us | FSLIB delete dir HDFS 每秒平均耗时 |
Starlet 每秒读取大小 | read_bytes | Bytes/s | Starlet 每秒读取大小 |
Starlet 每秒读取次数 | read_counts | Count/s | Starlet 每秒读取次数 |
Starlet 每秒写入大小 | write_bytes | Bytes/s | Starlet 每秒写入大小 |
Starlet 每秒写入次数 | write_counts | Count/s | Starlet 每秒写入次数 |
内存统计 | process | Bytes | process 内存占用 |
| metadata | Bytes | metadata 内存占用 |
| query | Bytes | query 内存占用 |
| load | Bytes | load 内存占用 |
| compaction | Bytes | compaction 内存占用 |
| update | Bytes | update 内存占用 |
| schema_change | Bytes | schema change 内存占用 |
| clone | Bytes | clone 内存占用 |
| chunk_allocator | Bytes | chunk allocator 内存占用 |
| consistency | Bytes | consistency 内存占用 |
| page_cache | Bytes | page cache 内存占用 |
| column_pool | Bytes | column pool 内存占用 |
| datacache | Bytes | datacache 内存占用 |
| jit_cache | Bytes | jit cache 内存占用 |
Metadata 内存统计 | tablet | Bytes | tablet metadata 内存占用 |
| rowset | Bytes | rowset metadata 内存占用 |
| segment | Bytes | segment metadata 内存占用 |
| column | Bytes | column metadata 内存占用 |
Tablet Metadata 内存统计 | tablet_schema | Bytes | tablet schema 内存占用 |
Segment Metadata 内存统计 | segment_zonemap | Bytes | segment zonemap 内存占用 |
| short_key_index | Bytes | short key index 内存占用 |
Column Metadata 内存统计 | bitmap_index | Bytes | bitmap cache 内存占用 |
| bf_index | Bytes | bloom fliter index cache 内存占用 |
| zonemap_index | Bytes | column zonemap cache 内存占用 |
| ordinal_index | Bytes | oridinal index cache 内存占用 |
Column Pool 内存统计 | binary | Bytes | binary column pool 内存占用 |
| uint8 | Bytes | uint8 column pool 内存占用 |
| int8 | Bytes | int8 column pool 内存占用 |
| int16 | Bytes | int16 column pool 内存占用 |
| int32 | Bytes | int32 column pool 内存占用 |
| int64 | Bytes | int64 column pool 内存占用 |
| int128 | Bytes | int128 column pool 内存占用 |
| float | Bytes | float column pool 内存占用 |
| double | Bytes | double column pool 内存占用 |
| decimal | Bytes | decimal column pool 内存占用 |
| date | Bytes | date column pool 内存占用 |
| datetime | Bytes | datetime column pool 内存占用 |
Result Block | block_count | Count | 结果缓存中的 Block 数 |
| queue_count | Count | 结果 Block 队列中的结果数量 |
打开Segment次数 | open_segments | Count | 每分钟打开的segment次数 |
| open_segments_io | Count | 每分钟打开segment生成IO任务的次数 |
Stream Load 导入数据量 | load_bytes | Bytes | Stream Load 导入的总字节数 |
Stream Load 导入耗时 | load_duration | ms | Stream Load 的总耗时 |
Stream Load 任务数量 | load_pipe_count | Count | 当前运行的 Stream Load 任务数量 |
| load_current_processing | Count | 当前运行的 Stream Load 任务数量 |
Stream Load 请求 | requests | Count | 每秒Stream Load 请求的次数 |
Transaction Stream Load 导入数据量 | load_bytes | Bytes | 通过 Stream Load 事务接口导入的字节数 |
Transaction Stream Load 导入耗时 | load_duration | ms | 事务导入的时间 |
Transaction Stream Load 任务数量 | current_processing | Count | 当前运行的 Transaction Stream Load 任务数量 |
Transaction Stream Load 请求 | load_requests | Count | 每秒Transaction Stream Load 请求的次数 |
Memtable Flush 次数 | flush_count | Count/s | Memtable Flush 的次数 |
Memtable Flush 大小 | flush_memory | Bytes | Memtable Flush memory数据大小 |
| flush_disk | Bytes | Memtable Flush disk数据大小 |
Memtable Flush 耗时 | flush_io | us | Memtable Flush IO耗时 |
| flush_duration | us | Memtable Flush 耗时 |
| finalize_duration | us | Memtable Flush finalize耗时 |
Segment Flush 大小 | flush_bytes | Bytes | Segment Flush 数据大小 |
Segment Flush 次数 | flush_count | Count/s | Segment Flush 次数 |
Segment Flush 耗时 | flush_duration | us | Segment Flush 耗时 |
| flush_io_duration | us | Segment Flush IO耗时 |
主键表Compaction的数量 | outputs_count | Count/s | 主键表Compaction的数量 |
主键表Compaction写入数据量 | outputs_bytes | Bytes | 主键表 Compaction 时写入的字节数 |
主键表Compaction耗时 | duration | us | 主键表 Compaction 任务的耗时 |
Routine Load任务数 | tasks | Count | 运行的 Routine Load 任务的数量 |
Spark Load 写入速率 | write_bytes | Bytes/s | Spark Load 的写入速率 |
Tablet 最大rowset数量 | rowset_nums | Count | tablet中最大rowset数 |
Load RPC 线程池大小 | size | Count | Load RPC 线程池大小 |
Load Channel 数量 | count | Count | Load Channel 数量 |
Add Chunks 耗时 | duration | us | add chunks 耗时 |
| wait_memtable | us | add chunks 等待memtable耗时 |
| wait_replica | us | add chunks 等待replica耗时 |
| wait_writer | us | add chunks 等待写入耗时 |
Add Chunks 次数 | count | Count/s | add chunks 次数 |
fragment request 次数 | count | Count/s | Fragment 实例的累积执行次数(非 Pipeline Engine ) |
导入数据量 | load_bytes | Bytes | 总导入字节数 |
导入行数 | load_rows | Count | 总导入行数 |
Async Delta Writer 执行次数 | async_delta_writer | Count | async delta writer 执行次数 |
Async Delta Writer Task 执行耗时 | execute | us | async delta writer task 执行时间 |
| pending | us | async delta writer task 等待时间 |
Async Delta Writer Task 执行次数 | count | Count | async delta writer task 执行次数 |
Update Apply 线程池耗时 | pending_time | ns | update apply 线程池排队时间 |
| execute_time | ns | update apply 线程池执行任务时长 |
| executed_tasks | Count/s | update apply 线程池已执行任务个数 |
| queue_count | Count | update apply 线程池排队任务数量 |
Update Apply 线程池大小 | active_threads | Count | update apply 线程池中active线程个数 |
| running_threads | Count | update apply 线程池中存活的线程个数 |
| threadpool_size | Count | update apply 线程池大小 |
Segment Replicate 线程池耗时 | pending_time | ns | segment replicate 线程池排队时间 |
| execute_time | ns | segment replicate 线程池执行任务时长 |
Segment Replicate 线程池任务 | executed_tasks | Count/s | segment replicate 线程池已执行任务个数 |
| queue_count | Count | segment replicate 线程池排队任务数量 |
Segment Replicate 线程池大小 | active_threads | Count | segment replicate 线程池中active线程个数 |
| running_threads | Count | segment replicate 线程池中存活的线程个数 |
| threadpool_size | Count | segment replicate 线程池大小 |
Segment Flush 线程池耗时 | pending_time | ns | segment flush 线程池排队时间 |
| execute_time | ns | segment flush 线程池执行任务时长 |
Segment Flush 线程池任务 | executed_tasks | Count/s | segment flush 线程池已执行任务个数 |
| queue_count | Count | segment flush 线程池排队任务数量 |
Segment Flush 线程池大小 | active_threads | Count | segment flush 线程池中active线程个数 |
| running_threads | Count | segment flush 线程池中存活的线程个数 |
| threadpool_size | Count | segment flush 线程池大小 |
Publish Version 线程池耗时 | pending_time | ns | publish version 线程池排队时间 |
| execute_time | ns | publish version 线程池执行任务时长 |
Publish Version 线程池任务 | executed_tasks | Count/s | publish version 线程池已执行任务个数 |
| queue_count | Count | publish version 线程池排队任务数量 |
Publish Version 线程池大小 | active_threads | Count | publish version 线程池中active线程个数 |
| running_threads | Count | publish version 线程池中存活的线程个数 |
| threadpool_size | Count | publish version 线程池大小 |
Primary Index Compaction 线程池耗时 | pending_time | ns | primary index compaction 线程池排队时间 |
| execute_time | ns | primary index compaction 线程池执行任务时长 |
Primary Index Compaction 线程池任务 | executed_tasks | Count/s | primary index compaction 线程池已执行任务个数 |
| queue_count | Count | primary index compaction 线程池排队任务数量 |
Primary Index Compaction 线程池大小 | active_threads | Count | primary index compaction 线程池中active线程个数 |
| running_threads | Count | primary index compaction 线程池中存活的线程个数 |
| threadpool_size | Count | primary index compaction 线程池大小 |
Memtable Flush 线程池耗时 | pending_time | ns | memtable flush 线程池排队时间 |
| execute_time | ns | memtable flush 线程池执行任务时长 |
Memtable Flush 线程池任务 | executed_tasks | Count/s | memtable flush 线程池已执行任务个数 |
| queue_count | Count | memtable flush 线程池排队任务数量 |
Memtable Flush 线程池大小 | active_threads | Count | memtable flush 线程池中active线程个数 |
| running_threads | Count | memtable flush 线程池中存活的线程个数 |
| threadpool_size | Count | memtable flush 线程池大小 |
Lake Memtable Flush 线程池耗时 | pending_time | ns | lake memtable flush 线程池排队时间 |
| execute_time | ns | lake memtable flush 线程池执行任务时长 |
Lake Memtable Flush 线程池任务 | executed_tasks | Count/s | lake memtable flush 线程池已执行任务个数 |
| queue_count | Count | lake memtable flush 线程池排队任务数量 |
Lake Memtable Flush 线程池大小 | active_threads | Count | lake memtable flush 线程池中active线程个数 |
| running_threads | Count | lake memtable flush 线程池中存活的线程个数 |
| threadpool_size | Count | lake memtable flush 线程池大小 |
Async Delta Writer 线程池耗时 | pending_time | ns | async delta writer 线程池排队时间 |
| execute_time | ns | async delta writer 线程池执行任务时长 |
Async Delta Writer 线程池任务 | executed_tasks | Count/s | async delta writer 线程池已执行任务个数 |
| queue_count | Count | async delta writer 线程池排队任务数量 |
Async Delta Writer 线程池大小 | active_threads | Count | async delta writer 线程池中active线程个数 |
| running_threads | Count | async delta writer 线程池中存活的线程个数 |
| threadpool_size | Count | async delta writer 线程池大小 |
更新rowset提交请求 | total | Count | 主键表中 RowsetCOMMIT 请求的总数 |
| failed | Count | 主键表中 RowsetCOMMIT 请求失败的总数 |
更新rowset提交应用次数 | total | Count | 主键表的 COMMIT 和 APPLY 的总数 |
更新rowset提交应用持续时间 | duration | us | 主键表 APPLY 任务的总耗时 |
THRIFT 客户端使用 | backend | Count | 当前使用的backend Thrift 客户端数 |
| broker | Count | 当前使用的broker Thrift 客户端数 |
| frontend | Count | 当前使用的frontend Thrift 客户端数 |
内存中主键索引的数量 | nums | Count | 内存中主键索引的数量 |
主键索引的总内存 | index_bytes | Bytes | 主键索引的总内存 |
主键表 DELETE Vector 缓存的内存占用 | delete_vector_bytes | Bytes | 主键表 DELETE Vector 缓存的内存成本 |
主键表中新生成的 DELETE 向量的总数 | new_delete_vector | Count | 主键表中新生成的 DELETE 向量的总数 |
主键表中 DELETE Vector 缓存项的数量 | delete_vector_counts | Count | 主键表中 DELETE Vector 缓存项的数量 |
Query Cache 使用率 | usage_ratio | % | query cache 使用率 |
Query Cache 大小 | capacity | Bytes | query cache 容量 |
Query Cache 大小 | usage | Bytes | query cache 使用量 |
Query Cache 命中率 | hit_ratio | % | query cache 命中率 |
Query Cache 次数 | lookup | Count | query cache 查询次数 |
| hit | Count | query cache 命中次数 |
Page Cache次数 | lookup | Count | page cache 查询次数 |
| hit | Count | page cache 命中次数 |
Page Cache 容量 | capacity | Bytes | page cache 容量 |
Brpc endpoint stub 个数 | count | Count | bRPC Stub 的总数(按主机地址计) |
Pipeline Driver 耗时 | driver_execution_time | ns | PipelineDriver Executor 处理 PipelineDriver 所用的时间 |
Pipeline 统计 | query_ctx_cnt | Count | 正在运行的查询的总数 |
| driver_queue_len | Count | 当前在 BE 中等待调度的 Ready Driver 的数量 |
| driver_schedule_count | Count | BE 中 Pipeline Executor 的 Driver 调度次数 |
| pipe_drivers | Count | 当前BE的总driver数 |
| poller_block_queue_len | Count | PipelineDriverPoller 的 Block 队列的当前长度 |
| perpare_pool_queue_len | Count | Pipeline Prepare 线程池中排队的任务数量 |
| scan_executor_queuing | Count | 当前由 Scan Operator 发起待执行的异步 I/O 任务的数量 |
PID | pid | None | 进程ID |
进程CPU使用率 | usage | % | CPU使用率 |
| system_usage | % | system CPU使用率 |
| user_usage | % | user CPU使用率 |
磁盘使用统计 | read | Bytes/s | 每秒磁盘读取字节数 |
| write | Bytes/s | 每秒磁盘写入字节数 |
进程FD统计 | fd_count | Count | 进程使用文件描述符的数量 |
线程总数 | thread_count | Count | 线程数量 |
进程启动时间 | uptime | s | 进程存活时间 |
最大磁盘IO使用率 | io_util | % | 最大磁盘使用百分比 |
Jemalloc 内存 | allocated | Bytes | Jemalloc分配的字节数 |
cn磁盘IO时间 | io_time | ms | IO操作时间 |
cn资源组CPU | in_use_cores | Count | 每个资源组当前正在使用的 CPU 核心的估计数量 |
cn资源组超限 | overflow_count | Count | 每个资源组触发并发限制的查询数量(瞬时值) |
cn资源组查询 | bigquery_count | Count | 每个资源组触发大查询限制的查询数量(瞬时值) |
| running_queries | Count | 每个资源组当前正在运行的查询数量(瞬时值) |
| total_queries | Count | 每个资源组执行的查询总数,包括当前正在运行的查询(瞬时值) |
cn资源组内存 | limit_bytes | Bytes | 每个资源组的内存限制(瞬时值) |
| inuse_bytes | Bytes | 每个资源组当前使用的内存(瞬时值) |
cn资源组CPU限制比率 | limit_ratio | % | 每个资源组 CPU 核心限制与所有资源组总 CPU 核心限制的比值(瞬时值) |
cn网络发送统计 | send | Bytes/s | 网络发送字节数 |
cn网络接收统计 | receive | Bytes/s | 网络接受字节数 |
CPU利用率 | ProcessCpuLoad | % | CPU利用率 |
GC次数 | YGC | Count | Young GC 次数 |
| FGC | Count | Full GC 次数 |
GC时间 | FGCT | s | Full GC 消耗时间 |
| GCT | s | 垃圾回收时间消耗 |
| YGCT | s | Young GC 消耗时间 |
内存区域占比 | S0 | % | Survivor 0区内存使用占比 |
| E | % | Eden 区内存使用占比 |
| CCS | % | Compressed class space 区内存使用占比 |
| S1 | % | Survivor 1区内存使用占比 |
| O | % | Old 区内存使用占比 |
| M | % | Metaspace 区内存使用占比 |
JVM内存 | MemHeapUsedM | MBytes | 已使用的堆内存 |
| MemNonHeapUsedM | MBytes | 已使用的堆外内存 |
| MemHeapCommittedM | MBytes | 已提交的堆内存 |
| MemNonHeapCommittedM | MBytes | 已提交的堆外内存 |
| MemHeapMaxM | MBytes | 最大堆内存 |
| MemHeapInitM | MBytes | 初始堆内存 |
| MemNonHeapInitM | MBytes | 初始堆外内存 |
文件句柄数 | MaxFileDescriptorCount | Count | 最大文件描述符数 |
| OpenFileDescriptorCount | Count | 打开文件描述符数 |
JVM线程数量 | PeakThreadCount | Count | 峰值线程数 |
| ThreadCount | Count | 总线程数量 |
| DaemonThreadCount | Count | Daemon线程数量 |