百度智能云

All Product Document

          Cloud Monitor

          MapReduce BMR

          MapReduce BMR includes 5 types of monitor objects: Cluster Monitor (Cluster), Host Monitor (Instance), Service Monitor (Service), Component Monitor (Component), and Topic Monitor (Topic). The dimensions involved are ClusterId, InstanceId, ServiceId, ComponentId, TopicId, and DiskName, with the dimension format as follows:

          • ClusterId:{{集群id}}
          • InstanceId:{{集群id}}-{{实例id}}
          • ServiceId: {{集群id}}-{{服务名}}
          • ComponentId: {{集群id}}-{{实例id}}-{{组件名}}
          • TopicId: {{集群id}}-KafkaTopic/HBaseTable-{{Topic名/HBase表名}}
          • DiskName: {{文件系统}}

          Note: For Cluster ID and Instance ID, please refer to MapReduce BMR Cluster details; please connect the cluster VM and view the file system via df command, e.g., "/dev/vdb"; write the service and component names with uppercase letters. View each dimension in Baidu Cloud Monitor (BCM) - Cloud Product Monitor - MapReduce BMR.
          The list of monitoring metrics for each type of monitor object is as follows:

          Cluster Monitor (Cluster)

          Metric name (English) Metric name (Chinese) Unit Dimension
          cluster_cpu_used_percent Average CPU utilization in cluster % ClusterId
          cluster_mem_total Total memory capacity in cluster GB ClusterId
          cluster_mem_used Memory usage in cluster GB ClusterId
          cluster_mem_used_percent Average memory utilization in cluster % ClusterId
          cluster_disk_total_size Total disk capacity in cluster GB ClusterId
          cluster_disk_total_free Free disk capacity in cluster GB ClusterId
          cluster_disk_total_used Total used disk capacity in cluster GB ClusterId

          Host Monitor (Instance)

          Metric name (English) Metric name (Chinese) Unit Dimension
          cpu_user User CPU utilization % InstanceId
          cpu_sys System CPU utilization % InstanceId
          cpu_idle CPU idle ratio % InstanceId
          cpu_wait_io CPU IO-wait time ratio % InstanceId
          mem_total Total memory GB InstanceId
          mem_used Memory usage GB InstanceId
          mem_free Free memory GB InstanceId
          mem_cached File system memory cache value GB InstanceId
          mem_buffers Block device I/O memory buffer usage GB InstanceId
          mem_used_percent Memory utilization % InstanceId
          swap_total Total swap partition GB InstanceId
          swap_free Idle swap partition GB InstanceId
          swap_used Swap partition usage GB InstanceId
          swap_used_percent Swap partition utilization % InstanceId
          disk_max_partition_used_percent Maximum disk partition utilization % InstanceId
          disk_total_size Total disk capacity GB InstanceId
          disk_total_free Free disk capacity GB InstanceId
          disk_total_used Total disk usage GB InstanceId
          disk_total_used_percent Total disk utilization % InstanceId
          disk_total_write_kb Total disk write rate KB/s InstanceId
          disk_total_read_kb Total disk read rate KB/s InstanceId
          disk_size Total capacity per single disk GB InstanceId,DiskName
          disk_free Available space per single disk GB InstanceId,DiskName
          disk_used Single disk usage GB InstanceId,DiskName
          disk_used_percent Single disk utilization % InstanceId,DiskName
          disk_write_kb Single disk write rate KB/s InstanceId,DiskName
          disk_read_kb Single disk read rate KB/s InstanceId,DiskName
          disk_io_util Single disk IO utilization % InstanceId,DiskName
          disk_max_partition_io_util Maximum disk IO utilization % InstanceId
          fd_limitation Host-wide fd upper limit Item InstanceId
          fd_used Host-wide allocated fd count Item InstanceId
          fd_used_percent Host-wide fd utilization % InstanceId
          loadavg5 Host load Item InstanceId
          net_total_in_bitps Host-wide network interface card ingress rate KB/s InstanceId
          net_total_out_bitps Host-wide network interface card egress rate KB/s InstanceId
          net_tcp_curr_estab Established TCP connections Item InstanceId
          net_total_sockets_used socket connection handlers Item InstanceId
          net_tcp_close_wait CLOSE_WAIT status connections Item InstanceId

          Service Monitor (Service)

          Metric name (English) Metric name (Chinese) Unit Dimension
          yarn_ClusterMetrics_NumActiveNMs Active nodemanagers Item ServiceId
          yarn_ClusterMetrics_NumLostNMs Lost nodemanagers Item ServiceId
          yarn_ClusterMetrics_NumUnhealthyNMs Unhealthy nodemanagers Item ServiceId
          yarn_QueueMetrics_TotalMB Total memory GB ServiceId
          yarn_QueueMetrics_TotalVCores Total vcores Item ServiceId
          yarn_QueueMetrics_ActiveApplications Active tasks Item ServiceId
          yarn_QueueMetrics_ActiveUsers Active users Item ServiceId
          yarn_QueueMetrics_AggregateContainersAllocated Total containers allocated Item ServiceId
          yarn_QueueMetrics_AggregateContainersReleased Total containers released Item ServiceId
          yarn_QueueMetrics_AllocatedContainers Total allocated containers Item ServiceId
          yarn_QueueMetrics_AllocatedMB Allocated memory GB ServiceId
          yarn_QueueMetrics_AllocatedVCores Allocated vcore Item ServiceId
          yarn_QueueMetrics_AppsCompleted Completed tasks Item ServiceId
          yarn_QueueMetrics_AppsPending Pending tasks Item ServiceId
          yarn_QueueMetrics_AppsRunning Running tasks Item ServiceId
          yarn_QueueMetrics_AppsSubmitted Submitted tasks Item ServiceId
          yarn_QueueMetrics_AvailableMB Available memory GB ServiceId
          yarn_QueueMetrics_AvailableVCores Available vcore Item ServiceId
          yarn_QueueMetrics_PendingContainers Pending containers Item ServiceId
          yarn_QueueMetrics_PendingMB Pending memory GB ServiceId
          yarn_QueueMetrics_PendingVCores Pending vcore Item ServiceId
          yarn_QueueMetrics_running_0 Tasks with runtime within 0-60 minutes Item ServiceId
          yarn_QueueMetrics_running_1440 Tasks with runtime over 1440 minutes Item ServiceId
          yarn_QueueMetrics_running_300 Tasks with runtime within 300-1440 minutes Item ServiceId
          yarn_QueueMetrics_running_60 Tasks with runtime within 60-300 minutes Item ServiceId
          yarn_QueueMetrics_AllocatedMem_precent Allocated memory proportion % ServiceId
          yarn_QueueMetrics_AllocatedVCore_precent Allocated VCore proportion % ServiceId
          dfs_FSNamesystem_BlockCapacity Total block capacity Item ServiceId
          dfs_FSNamesystem_BlocksTotal Current block capacity Item ServiceId
          dfs_FSNamesystem_CapacityRemainingGB Remaining HDFS capacity GB ServiceId
          dfs_FSNamesystem_CapacityTotalGB Total HDFS capacity GB ServiceId
          dfs_FSNamesystem_CapacityUsedGB Used HDFS capacity GB ServiceId
          dfs_FSNamesystem_CorruptBlocks Corrupt blocks Item ServiceId
          dfs_FSNamesystem_ExcessBlocks Over-replicated blocks Item ServiceId
          dfs_FSNamesystem_ExpiredHeartbeats Heartbeat timeout Item ServiceId
          dfs_FSNamesystem_FilesTotal Total number of files Item ServiceId
          dfs_FSNamesystem_LastCheckpointTime Last checkpoint time datatime ServiceId
          dfs_FSNamesystem_LastWrittenTransactionId Last written transaction ID Item ServiceId
          dfs_FSNamesystem_MillisSinceLastLoadedEdits Time since last edit load ms ServiceId
          dfs_FSNamesystem_MissingBlocks Missing blocks Item ServiceId
          dfs_FSNamesystem_UnderReplicatedBlocks Blocks with insufficient replicas Item ServiceId
          dfs_FSNamesystem_PendingDataNodeMessageCount datanode requests queued at standby NameNode Item ServiceId
          dfs_FSNamesystem_PendingDeletionBlocks Unverified blocks Item ServiceId
          dfs_FSNamesystem_PendingReplicationBlocks Under-replicated blocks Item ServiceId
          dfs_FSNamesystem_PostponedMisreplicatedBlocks Deferred corrupt blocks Item ServiceId
          dfs_FSNamesystem_ScheduledReplicationBlocks Pending replication blocks Item ServiceId
          dfs_FSNamesystem_TotalLoad namenode Xceiver count Item ServiceId
          dfs_FSNamesystem_TransactionsSinceLastCheckpoint New transaction count since last checkpoint Item ServiceId
          dfs_FSNamesystem_TransactionsSinceLastLogRoll New transaction count since last roll editlog Item ServiceId
          dfs_FSNamesystem_CapacityUsed_percent HDFS capacity utilization % ServiceId
          dfs_FSNamesystem_NumLiveDataNodes Healthy nodes per DataNode Item ServiceId
          dfs_FSNamesystem_NumDeadDataNodes Unhealthy nodes per DataNode Item ServiceId
          dfs_FSNamesystem_VolumeFailuresTotal Failed volumes per DataNode Item ServiceId
          dfs_namenode_Safemode Safe mode Item ServiceId
          hbase_ritCount Number of regions in RIT state Item ServiceId
          hbase_ritCountOverThreshold Number of regions in time-out RIT state Item ServiceId
          hbase_ritOldestAge Maximum duration of RIT state ms ServiceId
          hbase_averageLoad Average load Item ServiceId
          hbase_numRegionServers Number of active RS Item ServiceId
          hbase_numDeadRegionServers Number of stopped RS Item ServiceId
          hbase_clusterRequests Total cluster requests Item ServiceId
          hbase_mergePlanCount Pending Merge operations Item ServiceId
          hbase_splitPlanCount Pending Split operations Item ServiceId
          hbase_receivedBytes Received bytes Bytes ServiceId
          hbase_sentBytes Bytes sent Bytes ServiceId
          hbase_queueSize Queue size Item ServiceId
          hbase_numCallsInGeneralQueue Regular queue calls Time ServiceId
          hbase_numCallsInReplicationQueue Replica queue calls Time ServiceId
          hbase_numCallsInPriorityQueue Priority queue calls Time ServiceId
          hbase_numOpenConnections Persistent links size Item ServiceId
          hbase_numActiveHandler Active handler Item ServiceId
          hbase_numGeneralCallsDropped Dropped regular requests Time ServiceId
          hbase_numLifoModeSwitches Stack mode switches Time ServiceId
          hbase_authenticationSuccesses Authentication successes Time ServiceId
          hbase_authenticationFailures Authentication failures Time ServiceId
          hbase_authenticationFallbacks Authentication fallbacks Time ServiceId
          hbase_authorizationSuccesses Authorization successes Time ServiceId
          hbase_authorizationFailures Authorization failures Time ServiceId
          hbase_exceptions_RegionMovedException Region state transition failures Time ServiceId
          hbase_exceptions_multiResponseTooLarge Duplicate replies beyond threshold Time ServiceId
          hbase_exceptions_RegionTooBusyException RegionServer overload errors Time ServiceId
          hbase_exceptions_FailedSanityCheckException FailedSanityCheckException Time ServiceId
          hbase_exceptions_UnknownScannerException Unknown scan errors Time ServiceId
          hbase_exceptions_OutOfOrderScannerNextException Out-of-order scan errors Time ServiceId
          hbase_exceptions_NotServingRegionException NotServingRegionException Time ServiceId
          hbase_exceptions_callQueueTooBig Queue capacity exceeded errors Time ServiceId
          hbase_exceptions_ScannerResetException Scanner reset errors Time ServiceId
          hbase_exceptions Total errors Time ServiceId
          hbase_ProcessCallTime_num_ops Total operations Time ServiceId
          hbase_ProcessCallTime_min Minimum processing time ms ServiceId
          hbase_ProcessCallTime_max Maximum processing time ms ServiceId
          hbase_ProcessCallTime_mean Average processing time ms ServiceId
          hbase_QueueCallTime_num_ops Queue calls Time ServiceId
          hbase_QueueCallTime_min Minimum call time ms ServiceId
          hbase_QueueCallTime_max Maximum call time ms ServiceId
          hbase_QueueCallTime_mean Average call time ms ServiceId

          Component Monitor (Component)

          Metric name (English) Metric name (Chinese) Unit Dimension
          proc_cpu_usage Process CPU utilization % ComponentId
          proc_mem_usage Process memory utilization % ComponentId
          jvm_gc_O Old % ComponentId
          jvm_gc_E Young % ComponentId
          jvm_gc_M Metadata % ComponentId
          jvm_gc_CCS Compression ratio % ComponentId
          jvm_gc_YGCT Young GC duration s ComponentId
          jvm_gc_FGCT FullGC duration s ComponentId
          jvm_gc_GCT Overall GC duration s ComponentId
          jvm_gc_YGC Young GC count Time ComponentId
          jvm_gc_FGC FullGC times Time ComponentId
          hive_hs2_active_sessions Current active Session count Item ComponentId
          hive_hs2_open_sessions Current open Session count Item ComponentId
          hive_hs2_open_connections Current open connections Item ComponentId
          hive_hs2_cumulative_connection_count Cumulative connections Item ComponentId
          hive_hs2_active_calls_api_runTasks Current Runtask requests Item ComponentId
          hive_hs2_compiling_queries Average compilation time ms ComponentId
          hive_hs2_executing_queries Average query execution time ms ComponentId
          hive_hs2_submitted_queries Average query submission time ms ComponentId
          hive_hs2_succeeded_queries Successful queries since service startup Item ComponentId
          hive_hs2_sql_operation_active_user Current active users Item ComponentId
          hive_hs2_completed_sql_operation_FINISHED Total completed SQL count Item ComponentId
          hive_hs2_sql_operation_PENDING Average PEEDING duration of SQL tasks ms ComponentId
          hive_hs2_sql_operation_RUNNING Average RUNNING duration of SQL tasks ms ComponentId
          hive_metastore_active_calls_alter_table Current active AlterTable requests Time ComponentId
          hive_metastore_active_calls_create_table Current active CreateTable requests Time ComponentId
          hive_metastore_active_calls_drop_table Current active DropTable requests Time ComponentId
          hive_metastore_create_total_count_tables Tables created since service startup Item ComponentId
          hive_metastore_delete_total_count_tables Tables dropped since service startup Item ComponentId
          hive_metastore_api_alter_table Average time of AlterTable requests ms ComponentId
          hive_metastore_api_alter_table_with_environment_context Average time of AlterTableWithEnvContext requests ms ComponentId
          hive_metastore_api_create_table Average time of CreateTable requests ms ComponentId
          hive_metastore_api_create_table_with_environment_context Average time of CreateTableWithEnvContext requests ms ComponentId
          hive_metastore_api_drop_table Average time of DropTable requests ms ComponentId
          hive_metastore_api_drop_table_with_environment_context Average time of DropTableWithEnvContext requests ms ComponentId
          hive_metastore_api_get_table Average time of GetTable requests ms ComponentId
          hive_metastore_api_get_table_req Average time of GetTableReq requests ms ComponentId
          hive_metastore_api_get_table_objects_by_name_req Average time of GetTableObjectsByName requests ms ComponentId
          hive_metastore_api_get_tables Average time of GetTables requests ms ComponentId
          hive_metastore_api_get_tables_by_type Average time of GetTablesByType requests ms ComponentId
          hive_metastore_api_get_multi_table Average time of GetMultiTable requests ms ComponentId
          hive_metastore_api_get_table_statistics_req Average time of GetTableStatistics requests ms ComponentId
          hive_metastore_api_get_all_databases Average time of GetAllDatabases requests ms ComponentId
          hive_metastore_api_get_database Average time of GetDatabase requests ms ComponentId
          hive_metastore_api_get_databases Average time of GetDatabases requests ms ComponentId
          hive_metastore_api_get_all_functions Average time of GetAllFunctions requests ms ComponentId
          yarn_NodeManagerMetrics_AllocatedContainers Current allocated containers Item ComponentId
          yarn_NodeManagerMetrics_AllocatedGB Current allocated container memory GB ComponentId
          yarn_NodeManagerMetrics_AvailableGB Current free memory GB ComponentId
          yarn_NodeManagerMetrics_ContainersCompleted Completed containers Item ComponentId
          yarn_NodeManagerMetrics_ContainersIniting Initialized containers Item ComponentId
          yarn_NodeManagerMetrics_ContainersKilled Killed containers Item ComponentId
          yarn_NodeManagerMetrics_ContainersLaunched Containers in "Started" status Item ComponentId
          yarn_NodeManagerMetrics_ContainersRunning Containers in "Running" status Item ComponentId
          yarn_timeline_GetEntitiesOps Bulk entities fetch operations per TimelineServer Time ComponentId
          yarn_timeline_GetEntitiesTimeAvgTime Average bulk entities fetch time per TimelineServer ms ComponentId
          yarn_timeline_GetEntityOps Entity fetch operations per TimelineServer Time ComponentId
          yarn_timeline_GetEntityTimeAvgTime Average entity fetch time per TimelineServer ms ComponentId
          yarn_timeline_GetEventsOps Bulk events fetch operations per TimelineServer Time ComponentId
          yarn_timeline_GetEventsTimeAvgTime Average bulk events fetch time per TimelineServer ms ComponentId
          yarn_timeline_PostEntitiesOps Bulk entities update operations per TimelineServer Time ComponentId
          yarn_timeline_PostEntitiesTimeAvgTime Average bulk entities update time per TimelineServer ms ComponentId
          yarn_timeline_PutDomainOps Domain update operations per TimelineServer Time ComponentId
          yarn_timeline_PutDomainTimeAvgTime Average Domain update time per TimelineServer ms ComponentId
          yarn_timeline_GetDomainOps Domain fetch operations per TimelineServer Time ComponentId
          yarn_timeline_GetDomainTimeAvgTime Average Domain fetch time per TimelineServer ms ComponentId
          yarn_timeline_GetDomainsOps Bulk Domains fetch operations perTimelineServer Time ComponentId
          yarn_timeline_GetDomainsTimeAvgTime Average bulk Domains fetch time perTimelineServer ms ComponentId
          dfs_namenode_MemHeapCommitted Submitted heap memory MB ComponentId
          dfs_namenode_MemHeapMaxM Total heap memory MB ComponentId
          dfs_namenode_MemHeapUsedM Used heap memory MB ComponentId
          dfs_namenode_MemMaxM Maximum memory MB ComponentId
          dfs_namenode_MemNonHeapCommittedM Non-heap memory committed MB ComponentId
          dfs_namenode_MemNonHeapMaxM Maximum non-heap memory MB ComponentId
          dfs_namenode_MemNonHeapUsedM Non-heap memory usage MB ComponentId
          dfs_namenode_SafeModeTime Safemode time ms ComponentId
          dfs_namenode_AddBlockOps Write block count Time ComponentId
          dfs_namenode_BlockReportAvgTime Average time of block report ms ComponentId
          dfs_namenode_BlockReportNumOps block report count Time ComponentId
          dfs_namenode_CreateFileOps File creation count Time ComponentId
          dfs_namenode_DeleteFileOps File deletion count Time ComponentId
          dfs_namenode_FileInfoOps File info lookup count Time ComponentId
          dfs_namenode_FilesCreated Created files Item ComponentId
          dfs_namenode_FilesDeleted Deleted files Item ComponentId
          dfs_namenode_FilesInGetListingOps getlist operations Time ComponentId
          dfs_namenode_FilesRenamed Renamed files Item ComponentId
          dfs_namenode_FsImageLoadTime fsImage load time ms ComponentId
          dfs_namenode_GetAdditionalDatanodeOps GetAdditionalDatanode operations Time ComponentId
          dfs_namenode_GetBlockLocations GetBlockLocations operations Time ComponentId
          dfs_namenode_GetListingOps getListing operations Time ComponentId
          dfs_namenode_SyncsAvgTime Average editlog sync latency ms ComponentId
          dfs_namenode_SyncsNumOps editlog sync operations Time ComponentId
          dfs_namenode_TransactionsAvgTime Average transaction time ms ComponentId
          dfs_namenode_TransactionsBatchedInSync Transaction sync count at flush Time ComponentId
          dfs_namenode_TransactionsNumOps Number of transaction Item ComponentId
          dfs_datanode_MemHeapCommittedM Submitted heap memory MB ComponentId
          dfs_datanode_MemHeapMaxM Total heap memory MB ComponentId
          dfs_datanode_MemHeapUsedM Used heap memory MB ComponentId
          dfs_datanode_MemMaxM Maximum memory MB ComponentId
          dfs_datanode_MemNonHeapCommittedM Non-heap memory committed MB ComponentId
          dfs_datanode_MemNonHeapMaxM Maximum non-heap memory MB ComponentId
          dfs_datanode_MemNonHeapUsedM Non-heap memory usage MB ComponentId
          dfs_datanode_BlockReportsAvgTime Average latency of block report to namenode ms ComponentId
          dfs_datanode_BlockReportsNumOps Block reports to namenode Time ComponentId
          dfs_datanode_BlocksRead Disk block read operations Time ComponentId
          dfs_datanode_BlocksRemoved Deleted blocks Time ComponentId
          dfs_datanode_BlocksReplicated Block replication operations Item ComponentId
          dfs_datanode_BlocksVerified Block verification count Time ComponentId
          dfs_datanode_BlocksWritten Blocks written Item ComponentId
          dfs_datanode_BytesRead Total read bytes bytes ComponentId
          dfs_datanode_BytesWritten Total write bytes bytes ComponentId
          dfs_datanode_CopyBlockOpAvgTime Average block replication time ms ComponentId
          dfs_datanode_CopyBlockOpNumOps Block replication count Time ComponentId
          dfs_datanode_HeartbeatsAvgTime Average latency of report to namenode ms ComponentId
          dfs_datanode_HeartbeatsNumOps Reports to namenode Time ComponentId
          dfs_datanode_ReadBlockOpAvgTime Average block read time ms ComponentId
          dfs_datanode_ReadBlockOpNumOps Block read operations Time ComponentId
          dfs_datanode_ReadsFromLocalClient Local read operations Time ComponentId
          dfs_datanode_ReadsFromRemoteClient Remote read operations Time ComponentId
          dfs_datanode_WriteBlockOpAvgTime Average block write time ms ComponentId
          dfs_datanode_WriteBlockOpNumOps Block write operations Time ComponentId
          dfs_datanode_WritesFromLocalClient Local write operations Time ComponentId
          dfs_datanode_WritesFromRemoteClient Remote write operations Time ComponentId
          dfs_datanode_PacketAckRoundTripTimeNanosAvgTime Average packet acknowledgment time ms ComponentId
          dfs_datanode_PacketAckRoundTripTimeNanosNumOps Packet acknowledgment count Time ComponentId
          dfs_datanode_FlushNanosAvgTime flush average time of file system ms ComponentId
          dfs_datanode_FlushNanosNumOps flush average time of file system ms ComponentId
          dfs_datanode_ReplaceBlockOpAvgTime Average block replacement time ms ComponentId
          dfs_datanode_ReplaceBlockOpNumOps Block replacement count Time ComponentId
          dfs_datanode_SendDataPacketBlockedOnNetworkNanosAvgTime Average block send time on network ms ComponentId
          dfs_datanode_SendDataPacketBlockedOnNetworkNanosNumOps Blocks generated on network Time ComponentId
          dfs_datanode_SendDataPacketTransferNanosAvgTime Average packet send time on network ms ComponentId
          dfs_datanode_SendDataPacketTransferNanosNumOps Packets sent on network Item ComponentId
          dfs_datanode_FsStat_Capacity DataNode capacity GB ComponentId
          dfs_datanode_FsStat_DfsUsed DataNode usage GB ComponentId
          dfs_datanode_FsStat_NumFailedVolumes Failed volumes GB ComponentId
          LeaderCount leader partitions per broker Item ComponentId
          PartitionCount Partitions per broker Item ComponentId
          NetworkProcessorAvgIdlePercent IO thread utilization % ComponentId
          RequestHandlerAvgIdlePercent Thread processing request utilization % ComponentId
          ActiveControllerCount Controller nodes Item ComponentId
          UnderReplicatedPartitions Under-replicated replicas Item ComponentId
          OfflinePartitionsCount Offline replicas Item ComponentId
          PreferredReplicaImbalanceCount Preferred replica imbalances Item ComponentId
          LeaderElectionRateAndTimeMs Leader elections Time/s ComponentId
          UncleanLeaderElectionsPerSec Unsynchronized Leader elections Time/s ComponentId
          IsrShrinksPerSec ISR Shrink operations per second Time/s ComponentId
          IsrExpandsPerSec ISR Expand operations per second Time/s ComponentId
          TotalFetchRequestsPerSec Read requests per second Time/s ComponentId
          TotalProduceRequestsPerSec Write requests per second Time/s ComponentId
          BytesInPerSec Broker write traffic KB/s ComponentId
          BytesOutPerSec Broker read traffic KB/s ComponentId
          MessagesInPerSec Broker write messages Item/s ComponentId
          zk_avg_latency Average response latency ms ComponentId
          zk_max_latency Maximum response latency ms ComponentId
          zk_min_latency Minimum response latency ms ComponentId
          zk_packets_received Packets received Item ComponentId
          zk_packets_sent Number of Packets Sent Item ComponentId
          zk_num_alive_connections Active connections Item ComponentId
          zk_outstanding_requests Pending requests Item ComponentId
          zk_server_state Active/standby state Item ComponentId
          zk_znode_count znode count Item ComponentId
          zk_watch_count watch count Item ComponentId
          zk_ephemerals_count Temporary nodes Item ComponentId
          zk_approximate_data_size Approximate total data size bytes ComponentId
          zk_open_file_descriptor_count Open file descriptors Item ComponentId
          zk_max_file_descriptor_count Maximum file descriptors Item ComponentId
          zk_followers Follower count Item ComponentId
          zk_synced_followers Synchronized Followers Item ComponentId
          zk_pending_syncs Blocked sync operation Item ComponentId
          hbase_rs_averageRegionSize Average size of Region Bytes ComponentId
          hbase_rs_regionCount Number of Region Item ComponentId
          hbase_rs_percentFilesLocalSecondaryRegions Region replica locality % ComponentId
          hbase_rs_hlogFileCount Number of WAL files Item ComponentId
          hbase_rs_hlogFileSize Size of WAL files Bytes ComponentId
          hbase_rs_memStoreSize Memstore size MB ComponentId
          hbase_rs_storeCount Number of Store Item ComponentId
          hbase_rs_storeFileCount Number of Storefile Item ComponentId
          hbase_rs_storeFileSize Size of Storefile MB ComponentId
          hbase_rs_storeFileIndexSize storeFileIndexSize Bytes ComponentId
          hbase_rs_staticIndexSize staticIndexSize Bytes ComponentId
          hbase_rs_staticBloomSize staticBloomSize Bytes ComponentId
          hbase_rs_flushedCellsSize Disk flush size Bytes ComponentId
          hbase_rs_Append_mean Append_mean ms ComponentId
          hbase_rs_Replay_mean Append_mean ms ComponentId
          hbase_rs_Get_mean Append_mean ms ComponentId
          hbase_rs_updatesBlockedTime updatesBlockedTime ms ComponentId
          hbase_rs_FlushTime_num_ops RS disk writes Time ComponentId
          hbase_rs_splitQueueLength split queue requests Item ComponentId
          hbase_rs_compactionQueueLength Compaction queue requests Item ComponentId
          hbase_rs_totalRequestCount Total requests Time ComponentId
          hbase_rs_readRequestCount Read requests Time ComponentId
          hbase_rs_writeRequestCount Write requests Time ComponentId
          hbase_rs_compactedCellsCount Compacted cells count Item ComponentId
          hbase_rs_majorCompactedCellsCount Major compacted cells count Item ComponentId
          hbase_rs_splitRequestCount region split requests Time ComponentId
          hbase_rs_splitSuccessCount region split successes Time ComponentId
          hbase_rs_slowGetCount Slow requests >1000ms Time ComponentId
          hbase_rs_authenticationFailures RPC authentication failures Time ComponentId
          hbase_rs_authenticationSuccesses RPC authentication successes Time ComponentId
          hbase_rs_numOpenConnections RPC open connections Item ComponentId
          hbase_rs_exceptions_FailedSanityCheckException FailedSanityCheckException Time ComponentId
          hbase_rs_exceptions_NotServingRegionException NotServingRegionException Time ComponentId
          hbase_rs_exceptions_OutOfOrderScannerNextException OutOfOrderScannerNextException Time ComponentId
          hbase_rs_exceptions_RegionMovedException RegionMovedException Time ComponentId
          hbase_rs_exceptions_RegionTooBusyException RegionTooBusyException Time ComponentId
          hbase_rs_exceptions_UnknownScannerException UnknownScannerException Time ComponentId
          hbase_rs_exceptions Exceptions Time ComponentId
          hbase_rs_numActiveHandler RPC handler count Item ComponentId
          hbase_rs_numCallsInPriorityQueue numCallsInPriorityQueue Item ComponentId
          hbase_rs_numCallsInReplicationQueue numCallsInReplicationQueue Item ComponentId
          hbase_rs_numCallsInGeneralQueue numCallsInGeneralQueue Item ComponentId
          hbase_rs_receivedBytes Received bytes Bytes ComponentId
          hbase_rs_sentBytes Bytes sent Bytes ComponentId
          hbase_rs_queueSize Queue size Item ComponentId
          hbase_rs_blockCacheSize block cache size Bytes ComponentId
          hbase_rs_blockCacheFreeSize Remaining block cache size Bytes ComponentId
          hbase_rs_blockCacheCount Block cache hits Bytes ComponentId
          hbase_rs_blockCacheCountHitPercent Block cache hit rate % ComponentId
          hbase_rs_blockCacheExpressHitPercent Block cache open hit rate % ComponentId
          ck_server_event_InsertQuery ck_event_InsertQuery Time ComponentId
          ck_server_event_InsertedRows ck_event_InsertedRows Entry ComponentId
          ck_server_event_DelayedInserts ck_event_DelayedInserts Entry ComponentId
          ck_server_event_RejectedInserts ck_event_RejectedInserts Entry ComponentId
          ck_server_event_MergedRows ck_event_MergedRows Row ComponentId
          ck_server_metrics_BackgroundPoolTask ck_metrics_BackgroundPoolTask Item ComponentId
          ck_server_metrics_Merge ck_metrics_Merge Time ComponentId
          ck_server_metrics_MemoryTrackingForMerges ck_metrics_MemoryTrackingForMerges bytes ComponentId
          ck_server_metrics_PartMutation ck_metrics_PartMutation Item ComponentId
          ck_server_event_Query ck_event_Query Time ComponentId
          ck_server_event_SelectQuery ck_event_SelectQuery Time ComponentId
          ck_server_event_FailedQuery ck_event_FailedQuery Time ComponentId
          ck_server_event_SlowRead ck_event_SlowRead Item ComponentId
          ck_server_metrics_MemoryTracking ck_metrics_MemoryTracking bytes ComponentId
          ck_server_event_MarkCacheHits ck_event_MarkCacheHits Item ComponentId
          ck_server_event_MarkCacheMisses ck_event_MarkCacheMisses Item ComponentId
          ck_server_metrics_ReadonlyReplica ck_metrics_ReadonlyReplica Item ComponentId
          ck_server_metrics_ReplicatedFetch ck_metrics_ReplicatedFetch Item ComponentId
          ck_server_metrics_ReplicatedSend ck_metrics_ReplicatedSend Item ComponentId
          ck_server_event_ZooKeeperTransactions ck_event_ZooKeeperTransactions Item ComponentId
          ck_server_metrics_ZooKeeperSession ck_metrics_ZooKeeperSession Item ComponentId
          ck_server_metrics_ZooKeeperWatch ck_metrics_ZooKeeperWatch Item ComponentId
          ck_server_metrics_Query ck_metrics_Query Time ComponentId
          ck_server_metrics_ReplicatedChecks ck_metrics_ReplicatedChecks Item ComponentId
          ck_server_metrics_BackgroundMovePoolTask ck_metrics_BackgroundMovePoolTask Item ComponentId
          ck_server_metrics_BackgroundSchedulePoolTask ck_metrics_BackgroundSchedulePoolTask Item ComponentId
          ck_server_metrics_BackgroundBufferFlushSchedulePoolTask ck_metrics_BackgroundBufferFlushSchedulePoolTask Item ComponentId
          ck_server_metrics_BackgroundDistributedSchedulePoolTask ck_metrics_BackgroundDistributedSchedulePoolTask Item ComponentId
          ck_server_metrics_CacheDictionaryUpdateQueueBatches ck_metrics_CacheDictionaryUpdateQueueBatches Item ComponentId
          ck_server_metrics_CacheDictionaryUpdateQueueKeys ck_metrics_CacheDictionaryUpdateQueueKeys Item ComponentId
          ck_server_metrics_DiskSpaceReservedForMerge ck_metrics_DiskSpaceReservedForMerge bytes ComponentId
          ck_server_metrics_DistributedSend ck_metrics_DistributedSend Item ComponentId
          ck_server_metrics_QueryPreempted ck_metrics_QueryPreempted Item ComponentId
          ck_server_metrics_TCPConnection ck_metrics_TCPConnection Item ComponentId
          ck_server_metrics_MySQLConnection ck_metrics_MySQLConnection Item ComponentId
          ck_server_metrics_HTTPConnection ck_metrics_HTTPConnection Item ComponentId
          ck_server_metrics_InterserverConnection ck_metrics_InterserverConnection Item ComponentId
          ck_server_metrics_PostgreSQLConnection ck_metrics_PostgreSQLConnection Item ComponentId
          ck_server_metrics_OpenFileForRead ck_metrics_OpenFileForRead Item ComponentId
          ck_server_metrics_OpenFileForWrite ck_metrics_OpenFileForWrite Item ComponentId
          ck_server_metrics_Read ck_metrics_Read Item ComponentId
          ck_server_metrics_Write ck_metrics_Write Item ComponentId
          ck_server_metrics_SendScalars ck_metrics_SendScalars Item ComponentId
          ck_server_metrics_SendExternalTables ck_metrics_SendExternalTables Item ComponentId
          ck_server_metrics_QueryThread ck_metrics_QueryThread Item ComponentId
          ck_server_metrics_MemoryTrackingInBackgroundProcessingPool ck_metrics_MemoryTrackingInBackgroundProcessingPool bytes ComponentId
          ck_server_metrics_MemoryTrackingInBackgroundMoveProcessingPool ck_metrics_MemoryTrackingInBackgroundMoveProcessingPool bytes ComponentId
          ck_server_metrics_MemoryTrackingInBackgroundSchedulePool ck_metrics_MemoryTrackingInBackgroundSchedulePool bytes ComponentId
          ck_server_metrics_MemoryTrackingInBackgroundBufferFlushSchedulePool ck_metrics_MemoryTrackingInBackgroundBufferFlushSchedulePool bytes ComponentId
          ck_server_metrics_MemoryTrackingInBackgroundDistributedSchedulePool ck_metrics_MemoryTrackingInBackgroundDistributedSchedulePool bytes ComponentId
          ck_server_metrics_EphemeralNode ck_metrics_EphemeralNode Item ComponentId
          ck_server_metrics_ZooKeeperRequest ck_metrics_ZooKeeperRequest Item ComponentId
          ck_server_metrics_DelayedInserts ck_metrics_DelayedInserts Item ComponentId
          ck_server_metrics_ContextLockWait ck_metrics_ContextLockWait Item ComponentId
          ck_server_metrics_StorageBufferRows ck_metrics_StorageBufferRows Item ComponentId
          ck_server_metrics_StorageBufferBytes ck_metrics_StorageBufferBytes bytes ComponentId
          ck_server_metrics_DictCacheRequests ck_metrics_DictCacheRequests Item ComponentId
          ck_server_metrics_Revision ck_metrics_Revision Item ComponentId
          ck_server_metrics_VersionInteger ck_metrics_VersionInteger Version ComponentId
          ck_server_metrics_RWLockWaitingReaders ck_metrics_RWLockWaitingReaders Item ComponentId
          ck_server_metrics_RWLockWaitingWriters ck_metrics_RWLockWaitingWriters Item ComponentId
          ck_server_metrics_RWLockActiveReaders ck_metrics_RWLockActiveReaders Item ComponentId
          ck_server_metrics_RWLockActiveWriters ck_metrics_RWLockActiveWriters Item ComponentId
          ck_server_metrics_GlobalThread ck_metrics_GlobalThread Item ComponentId
          ck_server_metrics_GlobalThreadActive ck_metrics_GlobalThreadActive Item ComponentId
          ck_server_metrics_LocalThread ck_metrics_LocalThread Item ComponentId
          ck_server_metrics_LocalThreadActive ck_metrics_LocalThreadActive Item ComponentId
          ck_server_metrics_DistributedFilesToInsert ck_metrics_DistributedFilesToInsert Item ComponentId
          ck_server_event_FailedSelectQuery ck_event_FailedSelectQuery Time ComponentId
          ck_server_event_FailedInsertQuery ck_event_FailedInsertQuery Time ComponentId
          ck_server_event_FileOpen ck_event_FileOpen Item ComponentId
          ck_server_event_Seek ck_event_Seek Time ComponentId
          ck_server_event_ReadBufferFromFileDescriptorRead ck_event_ReadBufferFromFileDescriptorRead Item ComponentId
          ck_server_event_ReadBufferFromFileDescriptorReadBytes ck_event_ReadBufferFromFileDescriptorReadBytes bytes ComponentId
          ck_server_event_WriteBufferFromFileDescriptorWrite ck_event_WriteBufferFromFileDescriptorWrite Item ComponentId
          ck_server_event_WriteBufferFromFileDescriptorWriteFailed ck_event_WriteBufferFromFileDescriptorWriteFailed Item ComponentId
          ck_server_event_WriteBufferFromFileDescriptorWriteBytes ck_event_WriteBufferFromFileDescriptorWriteBytes bytes ComponentId
          ck_server_event_ReadCompressedBytes ck_event_ReadCompressedBytes bytes ComponentId
          ck_server_event_CompressedReadBufferBlocks ck_event_CompressedReadBufferBlocks Item ComponentId
          ck_server_event_CompressedReadBufferBytes ck_event_CompressedReadBufferBytes bytes ComponentId
          ck_server_event_IOBufferAllocs ck_event_IOBufferAllocs Item ComponentId
          ck_server_event_IOBufferAllocBytes ck_event_IOBufferAllocBytes bytes ComponentId
          ck_server_event_ArenaAllocChunks ck_event_ArenaAllocChunks Item ComponentId
          ck_server_event_ArenaAllocBytes ck_event_ArenaAllocBytes bytes ComponentId
          ck_server_event_FunctionExecute ck_event_FunctionExecute Item ComponentId
          ck_server_event_TableFunctionExecute ck_event_TableFunctionExecute Item ComponentId
          ck_server_event_CreatedReadBufferOrdinary ck_event_CreatedReadBufferOrdinary Item ComponentId
          ck_server_event_DiskReadElapsedMicroseconds ck_event_DiskReadElapsedMicroseconds μs ComponentId
          ck_server_event_DiskWriteElapsedMicroseconds ck_event_DiskWriteElapsedMicroseconds μs ComponentId
          ck_server_event_NetworkReceiveElapsedMicroseconds ck_event_NetworkReceiveElapsedMicroseconds μs ComponentId
          ck_server_event_NetworkSendElapsedMicroseconds ck_event_NetworkSendElapsedMicroseconds μs ComponentId
          ck_server_event_ReplicatedPartFetches ck_event_ReplicatedPartFetches Item ComponentId
          ck_server_event_ReplicatedPartMerges ck_event_ReplicatedPartMerges Item ComponentId
          ck_server_event_InsertedBytes ck_event_InsertedBytes bytes ComponentId
          ck_server_event_DelayedInsertsMilliseconds ck_event_DelayedInsertsMilliseconds ms ComponentId
          ck_server_event_ZooKeeperInit ck_event_ZooKeeperInit Item ComponentId
          ck_server_event_ZooKeeperList ck_event_ZooKeeperList Item ComponentId
          ck_server_event_ZooKeeperCreate ck_event_ZooKeeperCreate Item ComponentId
          ck_server_event_ZooKeeperWaitMicroseconds ck_event_ZooKeeperWaitMicroseconds μs ComponentId
          ck_server_event_ZooKeeperBytesSent ck_event_ZooKeeperBytesSent bytes ComponentId
          ck_server_event_ZooKeeperBytesReceived ck_event_ZooKeeperBytesReceived bytes ComponentId
          ck_server_event_ReadBackoff ck_event_ReadBackoff Item ComponentId
          ck_server_event_ReplicaPartialShutdown ck_event_ReplicaPartialShutdown Item ComponentId
          ck_server_event_SelectedParts ck_event_SelectedParts Item ComponentId
          ck_server_event_SelectedRanges ck_event_SelectedRanges Item ComponentId
          ck_server_event_SelectedMarks ck_event_SelectedMarks Item ComponentId
          ck_server_event_Merge ck_event_Merge Time ComponentId
          ck_server_event_MergedUncompressedBytes ck_event_MergedUncompressedBytes bytes ComponentId
          ck_server_event_MergesTimeMilliseconds ck_event_MergesTimeMilliseconds ms ComponentId
          ck_server_event_MergeTreeDataWriterRows ck_event_MergeTreeDataWriterRows Row ComponentId
          ck_server_event_MergeTreeDataWriterUncompressedBytes ck_event_MergeTreeDataWriterUncompressedBytes bytes ComponentId
          ck_server_event_MergeTreeDataWriterCompressedBytes ck_event_MergeTreeDataWriterCompressedBytes bytes ComponentId
          ck_server_event_MergeTreeDataWriterBlocks ck_event_MergeTreeDataWriterBlocks Item ComponentId
          ck_server_event_MergeTreeDataWriterBlocksAlreadySorted ck_event_MergeTreeDataWriterBlocksAlreadySorted Item ComponentId
          ck_server_event_CannotRemoveEphemeralNode ck_event_CannotRemoveEphemeralNode Item ComponentId
          ck_server_event_RegexpCreated ck_event_RegexpCreated Item ComponentId
          ck_server_event_ContextLock ck_event_ContextLock Item ComponentId
          ck_server_event_RWLockAcquiredReadLocks ck_event_RWLockAcquiredReadLocks Item ComponentId
          ck_server_event_RWLockAcquiredWriteLocks ck_event_RWLockAcquiredWriteLocks Item ComponentId
          ck_server_event_RWLockReadersWaitMilliseconds ck_event_RWLockReadersWaitMilliseconds ms ComponentId
          ck_server_event_RealTimeMicroseconds ck_event_RealTimeMicroseconds μs ComponentId
          ck_server_event_UserTimeMicroseconds ck_event_UserTimeMicroseconds μs ComponentId
          ck_server_event_SystemTimeMicroseconds ck_event_SystemTimeMicroseconds μs ComponentId
          ck_server_event_SoftPageFaults ck_event_SoftPageFaults Item ComponentId
          ck_server_event_OSIOWaitMicroseconds ck_event_OSIOWaitMicroseconds μs ComponentId
          ck_server_event_OSCPUWaitMicroseconds ck_event_OSCPUWaitMicroseconds μs ComponentId
          ck_server_event_OSCPUVirtualTimeMicroseconds ck_event_OSCPUVirtualTimeMicroseconds Item ComponentId
          ck_server_event_OSReadBytes ck_event_OSReadBytes bytes ComponentId
          ck_server_event_OSWriteBytes ck_event_OSWriteBytes bytes ComponentId
          ck_server_event_OSReadChars ck_event_OSReadChars Item ComponentId
          ck_server_event_OSWriteChars ck_event_OSWriteChars Item ComponentId
          ck_server_event_CreatedHTTPConnections ck_event_CreatedHTTPConnections Item ComponentId
          ck_server_event_QueryProfilerSignalOverruns ck_event_QueryProfilerSignalOverruns Item ComponentId
          ck_server_event_CreatedLogEntryForMerge ck_event_CreatedLogEntryForMerge Item ComponentId
          ck_server_async_metrics_NumberOfTables ck_async_metrics_NumberOfTables Item ComponentId
          ck_server_async_metrics_NumberOfDatabases ck_async_metrics_NumberOfDatabases Item ComponentId
          ck_server_async_metrics_MaxPartCountForPartition ck_async_metrics_MaxPartCountForPartition Item ComponentId
          ck_server_async_metrics_ReplicasSumQueueSize ck_async_metrics_ReplicasSumQueueSize Item ComponentId
          ck_server_async_metrics_ReplicasMaxMergesInQueue ck_async_metrics_ReplicasMaxMergesInQueue Item ComponentId
          ck_server_async_metrics_MemoryShared ck_async_metrics_MemoryShared bytes ComponentId
          ck_server_async_metrics_MemoryCode ck_async_metrics_MemoryCode bytes ComponentId
          ck_server_async_metrics_ReplicasMaxAbsoluteDelay ck_async_metrics_ReplicasMaxAbsoluteDelay Item ComponentId
          ck_server_async_metrics_ReplicasMaxQueueSize ck_async_metrics_ReplicasMaxQueueSize Item ComponentId
          ck_server_async_metrics_MemoryVirtual ck_async_metrics_MemoryVirtual bytes ComponentId
          ck_server_async_metrics_MarkCacheBytes ck_async_metrics_MarkCacheBytes bytes ComponentId
          ck_server_async_metrics_CompiledExpressionCacheCount ck_async_metrics_CompiledExpressionCacheCount Item ComponentId
          ck_server_async_metrics_ReplicasSumMergesInQueue ck_async_metrics_ReplicasSumMergesInQueue Item ComponentId
          ck_server_async_metrics_UncompressedCacheBytes ck_async_metrics_UncompressedCacheBytes Item ComponentId
          ck_server_async_metrics_ReplicasSumInsertsInQueue ck_async_metrics_ReplicasSumInsertsInQueue Item ComponentId
          ck_server_async_metrics_MarkCacheFiles ck_async_metrics_MarkCacheFiles Item ComponentId
          ck_server_async_metrics_MemoryDataAndStack ck_async_metrics_MemoryDataAndStack bytes ComponentId
          ck_server_async_metrics_MemoryResident ck_async_metrics_MemoryResident bytes ComponentId
          ck_server_async_metrics_ReplicasMaxInsertsInQueue ck_async_metrics_ReplicasMaxInsertsInQueue Item ComponentId
          ck_server_async_metrics_ReplicasMaxRelativeDelay ck_async_metrics_ReplicasMaxRelativeDelay Item ComponentId
          ck_server_async_metrics_UncompressedCacheCells ck_async_metrics_UncompressedCacheCells Item ComponentId
          kudu_master_data_dirs_failed Failed data directories Item ComponentId
          kudu_master_data_dirs_full Full data directories Item ComponentId
          kudu_master_glog_error_messages ERROR-level log messages in master Time ComponentId
          kudu_master_glog_warning_messages WARNING-level log messages in master Time ComponentId
          kudu_master_rpc_connections_accepted RPC requests received in master Item ComponentId
          kudu_master_rpc_incoming_queue_time_percentile_99 RPC queue wait time P99 in master ms ComponentId
          kudu_master_rpcs_queue_overflow RPC queue overflows in master Time ComponentId
          kudu_master_rpcs_timed_out_in_queue RPC wait timeout in master ms ComponentId
          kudu_master_threads_running master threads Item ComponentId
          kudu_master_inbound_connections_socket_stats_pacing_rate_max Maximum network ingress traffic per millisecond in master kps ComponentId
          kudu_master_inbound_connections_socket_stats_pacing_rate_min Minimum network ingress traffic per millisecond in master kps ComponentId
          kudu_master_inbound_connections_socket_stats_rtt_max Maximum network inbound round-trip time in master ms ComponentId
          kudu_master_inbound_connections_socket_stats_rtt_min Minimum network inbound round-trip time in master ms ComponentId
          kudu_master_inbound_connections_socket_stats_rttvar_max Maximum average deviation of network inbound round-trip time in master ms ComponentId
          kudu_master_inbound_connections_socket_stats_rttvar_min Minimum average deviation of network inbound round-trip time in master ms ComponentId
          kudu_master_outbound_connections_socket_stats_pacing_rate_max Maximum network egress traffic per millisecond in master kps ComponentId
          kudu_master_outbound_connections_socket_stats_pacing_rate_min Minimum network egress traffic per millisecond in master kps ComponentId
          kudu_master_outbound_connections_socket_stats_rtt_max Maximum network outbound round-trip time in master ms ComponentId
          kudu_master_outbound_connections_socket_stats_rtt_min Minimum network outbound round-trip time in master ms ComponentId
          kudu_master_outbound_connections_socket_stats_rttvar_max Maximum average deviation of network outbound round-trip time in master ms ComponentId
          kudu_master_outbound_connections_socket_stats_rttvar_min Minimum average deviation of network outbound round-trip time in master ms ComponentId
          kudu_tserver_inbound_connections_socket_stats_pacing_rate_max Maximum network ingress traffic per millisecond in tserver kps ComponentId
          kudu_tserver_inbound_connections_socket_stats_pacing_rate_min Minimum network ingress traffic per millisecond in tserver kps ComponentId
          kudu_tserver_inbound_connections_socket_stats_rtt_max Maximum network inbound round-trip time in tserver ms ComponentId
          kudu_tserver_inbound_connections_socket_stats_rtt_min Minimum network inbound round-trip time in tserver ms ComponentId
          kudu_tserver_inbound_connections_socket_stats_rttvar_max Maximum average deviation of network inbound round-trip time in tserver ms ComponentId
          kudu_tserver_inbound_connections_socket_stats_rttvar_min Minimum average deviation of network inbound round-trip time in tserver ms ComponentId
          kudu_tserver_outbound_connections_socket_stats_pacing_rate_max Maximum network egress traffic per millisecond in tserver kps ComponentId
          kudu_tserver_outbound_connections_socket_stats_pacing_rate_min Minimum network egress traffic per millisecond in tserver kps ComponentId
          kudu_tserver_outbound_connections_socket_stats_rtt_max Maximum network outbound round-trip time in tserver ms ComponentId
          kudu_tserver_outbound_connections_socket_stats_rtt_min Minimum network outbound round-trip time in tserver ms ComponentId
          kudu_tserver_outbound_connections_socket_stats_rttvar_max Maximum average deviation of network outbound round-trip time in tserver ms ComponentId
          kudu_tserver_outbound_connections_socket_stats_rttvar_min Minimum average deviation of network outbound round-trip time in tserver ms ComponentId
          kudu_tserver_active_scanners Active scanners Item ComponentId
          kudu_tserver_block_cache_usage Block cache memory usage in tserver byte ComponentId
          kudu_tserver_cpu_stime Total system CPU time in tserver s ComponentId
          kudu_tserver_cpu_utime Total user CPU time in tserver s ComponentId
          kudu_tserver_glog_error_messages ERROR-level log messages in tserver Time ComponentId
          kudu_tserver_memrowset_size Rows stored in memory Row ComponentId
          kudu_tserver_num_rowsets_on_disk Rows stored on disk Row ComponentId
          kudu_tserver_op_apply_queue_length_percentile_99 Operation queue length P99 Item ComponentId
          kudu_tserver_op_apply_queue_time_percentile_99 Operation queue wait time P99 ms ComponentId
          kudu_tserver_op_apply_run_time_percentile_99 Operation execution time P99 ms ComponentId
          kudu_tserver_reactor_load_percent_percentile_99 reactor thread load P99 Item ComponentId
          kudu_tserver_rows_deleted Rows deleted per node Row ComponentId
          kudu_tserver_rows_inserted Rows inserted per node Row ComponentId
          kudu_tserver_rows_updated Rows updated per node Row ComponentId
          kudu_tserver_rows_upserted Upserted Rows per node Row ComponentId
          kudu_tserver_scanner_duration_percentile_99 scanner time P99 ms ComponentId
          kudu_tserver_tablets_num_failed Failed tablets Item ComponentId
          kudu_tserver_tablets_num_running Current running tablets Item ComponentId
          kudu_tserver_tablets_num_shutdown Current shutdown tablets Item ComponentId
          kudu_tserver_tablets_num_stopped Current stopped tablets Item ComponentId
          kudu_tserver_tcmalloc_current_total_thread_cache_bytes TCMalloc memory usage by tserver threads byte ComponentId
          kudu_tserver_threads_running tablet server threads Item ComponentId
          trino_running_queries Total active queries Item ComponentId
          trino_queued_queries Total queued queries Item ComponentId
          trino_failed_queries Failed queries Item/min ComponentId
          trino_abandoned_queries Abandoned queries Item/min ComponentId
          trino_canceled_queries Canceled queries Item/min ComponentId
          trino_completed_queries Completed queries Item/min ComponentId
          trino_started_queries Total initiated queries Item/min ComponentId
          trino_input_data_size_one_minute Input data rate GB/min ComponentId
          trino_output_data_size_one_minute Output data rate GB/min ComponentId
          impala_catalog_impala_thrift_server_CatalogService_connections_in_use Current active connections Item ComponentId
          impala_catalog_thread_manager_total_threads_created Threads created in catalogd Item ComponentId
          impala_catalog_memory_total_used Total memory usage in catalogd byte ComponentId
          impala_catalog_memory_rss Physical memory usage in catalogd byte ComponentId
          impala_statestore_live_backends StateStore subscribers Item ComponentId
          impala_statestore_thread_manager_total_threads_created Threads created in statestored Item ComponentId
          impala_statestore_memory_total_used Total memory usage in statestored byte ComponentId
          impala_statestore_memory_rss Physical memory usage in statestored byte ComponentId
          impalad_metrics_impala_server_query_durations_ms_50th Completed query latency P50 ms ComponentId
          impalad_metrics_impala_server_query_durations_ms_90th Completed query latency P90 ms ComponentId
          impalad_metrics_impala_server_query_durations_ms_99_9th Completed query latency P99.9 ms ComponentId
          impalad_metrics_impala_server_num_queries Total queries processed in process lifetime Item ComponentId
          impalad_metrics_impala_server_num_queries_registered Total registered queries Item ComponentId
          impalad_metrics_impala_server_ddl_durations_ms_50th Completed DDL latency P50 ms ComponentId
          impalad_metrics_impala_server_ddl_durations_ms_90th Completed DDL latency P90 ms ComponentId
          impalad_metrics_impala_server_ddl_durations_ms_99_9th Completed DDL latency P99 ms ComponentId
          impalad_metrics_impala_server_num_queries_expired Expired idle queries Item ComponentId
          impalad_metrics_impala_thrift_server_backend_connections_in_use Current active connections at ThriftServer backend Item ComponentId
          impalad_metrics_impala_thrift_server_beeswax_frontend_connections_in_use Current active connections at beeswaxfrontend Item ComponentId
          impalad_metrics_impala_thrift_server_hiveserver2_frontend_connections_in_use Current active connections at Hiveserver2 frontend Item ComponentId
          impalad_metrics_impala_thrift_server_hiveserver2_frontend_total_connections Connections at Hiveserver2 frontend Item ComponentId
          impalad_metrics_impala_thrift_server_beeswax_frontend_total_connections Connections at Beeswax frontend Item ComponentId
          impalad_metrics_thread_manager_total_threads_created Threads created in impalad Item ComponentId
          impalad_metrics_memory_total_used Total memory usage in impalad byte ComponentId
          impalad_metrics_memory_rss Physical memory usage in impalad byte ComponentId
          impalad_metrics_impala_server_num_fragments Total completed fragments Item ComponentId
          impalad_metrics_impala_server_num_fragments_in_flight Running fragments Item ComponentId

          Topic Monitor (Topic)

          Metric name (English) Metric name (Chinese) Unit Dimension
          BytesInPerSec_topic Topic write traffic KB/s TopicId
          BytesOutPerSec_topic Topic read traffic KB/s TopicId
          MessagesInPerSec_topic Messages written to topic Item/s TopicId
          hbase_tb_tableSize hbase_tableSize Bytes TopicId
          hbase_tb_storeFileSize hbase_storeFileSize Bytes TopicId
          hbase_tb_readRequestCount hbase_readRequestCount Item TopicId
          hbase_tb_writeRequestCount hbase_writeRequestCount Item TopicId
          hbase_tb_totalRequestCount hbase_totalRequestCount Item TopicId
          hbase_tb_memstoreSize hbase_memstoreSize Bytes TopicId
          Previous
          Log Service BLS
          Next
          Message service for Kafka-dedicated