Skip to content

Instantly share code, notes, and snippets.

@shemnon
Created January 14, 2020 23:50
Show Gist options
  • Save shemnon/bff32ff78ff42cb2d51f76effba0d311 to your computer and use it in GitHub Desktop.
Save shemnon/bff32ff78ff42cb2d51f76effba0d311 to your computer and use it in GitHub Desktop.
Mechanical dump of all of the Besu metrics
# HELP besu_blockchain_chain_head_gas_limit Block gas limit of the current chain head block
# TYPE besu_blockchain_chain_head_gas_limit gauge
# HELP besu_blockchain_chain_head_gas_used Gas used by the current chain head block
# TYPE besu_blockchain_chain_head_gas_used gauge
# HELP besu_blockchain_chain_head_ommer_count Number of ommers in the current chain head block
# TYPE besu_blockchain_chain_head_ommer_count gauge
# HELP besu_blockchain_chain_head_timestamp Timestamp from the current chain head
# TYPE besu_blockchain_chain_head_timestamp gauge
# HELP besu_blockchain_chain_head_transaction_count Number of transactions in the current chain head block
# TYPE besu_blockchain_chain_head_transaction_count gauge
# HELP besu_blockchain_difficulty_total Total difficulty of the chainhead
# TYPE besu_blockchain_difficulty_total gauge
# HELP besu_executors_ethscheduler_computation_active_threads_current Current number of threads executing tasks
# TYPE besu_executors_ethscheduler_computation_active_threads_current gauge
# HELP besu_executors_ethscheduler_computation_completed_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_computation_completed_tasks_total gauge
# HELP besu_executors_ethscheduler_computation_pool_size_current Current number of threads in the thread pool
# TYPE besu_executors_ethscheduler_computation_pool_size_current gauge
# HELP besu_executors_ethscheduler_computation_queue_length_current Current number of tasks awaiting execution
# TYPE besu_executors_ethscheduler_computation_queue_length_current gauge
# HELP besu_executors_ethscheduler_computation_rejected_tasks_total Total number of tasks rejected by this executor
# TYPE besu_executors_ethscheduler_computation_rejected_tasks_total counter
# HELP besu_executors_ethscheduler_computation_submitted_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_computation_submitted_tasks_total gauge
# HELP besu_executors_ethscheduler_services_active_threads_current Current number of threads executing tasks
# TYPE besu_executors_ethscheduler_services_active_threads_current gauge
# HELP besu_executors_ethscheduler_services_completed_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_services_completed_tasks_total gauge
# HELP besu_executors_ethscheduler_services_pool_size_current Current number of threads in the thread pool
# TYPE besu_executors_ethscheduler_services_pool_size_current gauge
# HELP besu_executors_ethscheduler_services_queue_length_current Current number of tasks awaiting execution
# TYPE besu_executors_ethscheduler_services_queue_length_current gauge
# HELP besu_executors_ethscheduler_services_rejected_tasks_total Total number of tasks rejected by this executor
# TYPE besu_executors_ethscheduler_services_rejected_tasks_total counter
# HELP besu_executors_ethscheduler_services_submitted_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_services_submitted_tasks_total gauge
# HELP besu_executors_ethscheduler_timer_active_threads_current Current number of threads executing tasks
# TYPE besu_executors_ethscheduler_timer_active_threads_current gauge
# HELP besu_executors_ethscheduler_timer_completed_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_timer_completed_tasks_total gauge
# HELP besu_executors_ethscheduler_timer_pool_size_current Current number of threads in the thread pool
# TYPE besu_executors_ethscheduler_timer_pool_size_current gauge
# HELP besu_executors_ethscheduler_timer_queue_length_current Current number of tasks awaiting execution
# TYPE besu_executors_ethscheduler_timer_queue_length_current gauge
# HELP besu_executors_ethscheduler_timer_rejected_tasks_total Total number of tasks rejected by this executor
# TYPE besu_executors_ethscheduler_timer_rejected_tasks_total counter
# HELP besu_executors_ethscheduler_timer_submitted_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_timer_submitted_tasks_total gauge
# HELP besu_executors_ethscheduler_transactions_active_threads_current Current number of threads executing tasks
# TYPE besu_executors_ethscheduler_transactions_active_threads_current gauge
# HELP besu_executors_ethscheduler_transactions_completed_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_transactions_completed_tasks_total gauge
# HELP besu_executors_ethscheduler_transactions_dropped_tasks_total Total number of tasks rejected by this working queue.
# TYPE besu_executors_ethscheduler_transactions_dropped_tasks_total counter
# HELP besu_executors_ethscheduler_transactions_pool_size_current Current number of threads in the thread pool
# TYPE besu_executors_ethscheduler_transactions_pool_size_current gauge
# HELP besu_executors_ethscheduler_transactions_queue_length_current Current number of tasks awaiting execution
# TYPE besu_executors_ethscheduler_transactions_queue_length_current gauge
# HELP besu_executors_ethscheduler_transactions_rejected_tasks_total Total number of tasks rejected by this executor
# TYPE besu_executors_ethscheduler_transactions_rejected_tasks_total counter
# HELP besu_executors_ethscheduler_transactions_submitted_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_transactions_submitted_tasks_total gauge
# HELP besu_executors_ethscheduler_workers_active_threads_current Current number of threads executing tasks
# TYPE besu_executors_ethscheduler_workers_active_threads_current gauge
# HELP besu_executors_ethscheduler_workers_completed_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_workers_completed_tasks_total gauge
# HELP besu_executors_ethscheduler_workers_pool_size_current Current number of threads in the thread pool
# TYPE besu_executors_ethscheduler_workers_pool_size_current gauge
# HELP besu_executors_ethscheduler_workers_queue_length_current Current number of tasks awaiting execution
# TYPE besu_executors_ethscheduler_workers_queue_length_current gauge
# HELP besu_executors_ethscheduler_workers_rejected_tasks_total Total number of tasks rejected by this executor
# TYPE besu_executors_ethscheduler_workers_rejected_tasks_total counter
# HELP besu_executors_ethscheduler_workers_submitted_tasks_total Total number of tasks executed
# TYPE besu_executors_ethscheduler_workers_submitted_tasks_total gauge
# HELP besu_network_discovery_inflight_interactions_current Current number of inflight discovery interactions
# TYPE besu_network_discovery_inflight_interactions_current gauge
# HELP besu_network_discovery_interaction_count Total number of discovery interactions initiated
# TYPE besu_network_discovery_interaction_count counter
# HELP besu_network_discovery_interaction_retry_count Total number of interaction retries performed
# TYPE besu_network_discovery_interaction_retry_count counter
# HELP besu_network_discovery_messages_inbound Total number of P2P discovery messages received
# TYPE besu_network_discovery_messages_inbound counter
# HELP besu_network_discovery_messages_outbound Total number of P2P discovery messages sent
# TYPE besu_network_discovery_messages_outbound counter
# HELP besu_network_netty_boss_pending_tasks The number of pending tasks in the Netty boss event loop
# TYPE besu_network_netty_boss_pending_tasks gauge
# HELP besu_network_netty_workers_pending_tasks The number of pending tasks in the Netty workers event loop
# TYPE besu_network_netty_workers_pending_tasks gauge
# HELP besu_network_p2p_messages_inbound Count of each P2P message received inbound.
# TYPE besu_network_p2p_messages_inbound counter
# HELP besu_network_p2p_messages_outbound Count of each P2P message sent outbound.
# TYPE besu_network_p2p_messages_outbound counter
# HELP besu_network_vertx_eventloop_pending_tasks The number of pending tasks in the Vertx event loop
# TYPE besu_network_vertx_eventloop_pending_tasks gauge
# HELP besu_network_vertx_worker_pool_completed_total Total number of tasks completed by the Vertx worker pool
# TYPE besu_network_vertx_worker_pool_completed_total counter
# HELP besu_network_vertx_worker_pool_rejected_total Total number of tasks rejected by the Vertx worker pool
# TYPE besu_network_vertx_worker_pool_rejected_total counter
# HELP besu_network_vertx_worker_pool_submitted_total Total number of tasks submitted to the Vertx worker pool
# TYPE besu_network_vertx_worker_pool_submitted_total counter
# HELP besu_peers_connected_total Total number of peers connected
# TYPE besu_peers_connected_total counter
# HELP besu_peers_disconnected_total Total number of peers disconnected
# TYPE besu_peers_disconnected_total counter
# HELP besu_peers_pending_peer_requests_current Number of peer requests currently pending because peers are busy
# TYPE besu_peers_pending_peer_requests_current gauge
# HELP besu_rocksdb_commit_latency_seconds Latency for commits to RocksDB.
# TYPE besu_rocksdb_commit_latency_seconds summary
# HELP besu_rocksdb_read_latency_seconds Latency for read from RocksDB.
# TYPE besu_rocksdb_read_latency_seconds summary
# HELP besu_rocksdb_remove_latency_seconds Latency of remove requests from RocksDB.
# TYPE besu_rocksdb_remove_latency_seconds summary
# HELP besu_rocksdb_rocks_db_files_size_bytes Estimated database size in bytes
# TYPE besu_rocksdb_rocks_db_files_size_bytes gauge
# HELP besu_rocksdb_rocks_db_table_readers_memory_bytes Estimated memory used for RocksDB index and filter blocks in bytes
# TYPE besu_rocksdb_rocks_db_table_readers_memory_bytes gauge
# HELP besu_rocksdb_rollback_count Number of RocksDB transactions rolled back.
# TYPE besu_rocksdb_rollback_count counter
# HELP besu_rocksdb_write_latency_seconds Latency for write to RocksDB.
# TYPE besu_rocksdb_write_latency_seconds summary
# HELP besu_rpc_request_time Time taken to process a JSON-RPC request
# TYPE besu_rpc_request_time summary
# HELP besu_rpc_subscription_subscribe_total Total number of subscriptions
# TYPE besu_rpc_subscription_subscribe_total counter
# HELP besu_rpc_subscription_unsubscribe_total Total number of unsubscriptions
# TYPE besu_rpc_subscription_unsubscribe_total counter
# HELP besu_synchronizer_chain_download_pipeline_processed_total Number of entries process by each chain download pipeline stage
# TYPE besu_synchronizer_chain_download_pipeline_processed_total counter
# HELP besu_synchronizer_chain_download_pipeline_restarts Number of times the chain download pipeline has been restarted
# TYPE besu_synchronizer_chain_download_pipeline_restarts counter
# HELP besu_synchronizer_in_sync Whether or not the local node has caught up to the best known peer
# TYPE besu_synchronizer_in_sync gauge
# HELP besu_synchronizer_task Internal processing tasks
# TYPE besu_synchronizer_task summary
# HELP besu_transaction_pool_transactions_added_total Count of transactions added to the transaction pool
# TYPE besu_transaction_pool_transactions_added_total counter
# HELP besu_transaction_pool_transactions_duplicates_total Total number of duplicate transactions received
# TYPE besu_transaction_pool_transactions_duplicates_total counter
# HELP besu_transaction_pool_transactions_messages_skipped_total Total number of transactions messages skipped by the processor.
# TYPE besu_transaction_pool_transactions_messages_skipped_total counter
# HELP besu_transaction_pool_transactions_removed_total Count of transactions removed from the transaction pool
# TYPE besu_transaction_pool_transactions_removed_total counter
# HELP ethereum_best_known_block_number The estimated highest block available
# TYPE ethereum_best_known_block_number gauge
# HELP ethereum_blockchain_height The current height of the canonical chain
# TYPE ethereum_blockchain_height gauge
# HELP ethereum_peer_count The current number of peers connected
# TYPE ethereum_peer_count gauge
# HELP ethereum_peer_limit The maximum number of peers this node allows to connect
# TYPE ethereum_peer_limit gauge
# HELP jvm_buffer_pool_capacity_bytes Bytes capacity of a given JVM buffer pool.
# TYPE jvm_buffer_pool_capacity_bytes gauge
# HELP jvm_buffer_pool_used_buffers Used buffers of a given JVM buffer pool.
# TYPE jvm_buffer_pool_used_buffers gauge
# HELP jvm_buffer_pool_used_bytes Used bytes of a given JVM buffer pool.
# TYPE jvm_buffer_pool_used_bytes gauge
# HELP jvm_classes_loaded The number of classes that are currently loaded in the JVM
# TYPE jvm_classes_loaded gauge
# HELP jvm_classes_loaded_total The total number of classes that have been loaded since the JVM has started execution
# TYPE jvm_classes_loaded_total counter
# HELP jvm_classes_unloaded_total The total number of classes that have been unloaded since the JVM has started execution
# TYPE jvm_classes_unloaded_total counter
# HELP jvm_gc_collection_seconds Time spent in a given JVM garbage collector in seconds.
# TYPE jvm_gc_collection_seconds summary
# HELP jvm_memory_bytes_committed Committed (bytes) of a given JVM memory area.
# TYPE jvm_memory_bytes_committed gauge
# HELP jvm_memory_bytes_init Initial bytes of a given JVM memory area.
# TYPE jvm_memory_bytes_init gauge
# HELP jvm_memory_bytes_max Max (bytes) of a given JVM memory area.
# TYPE jvm_memory_bytes_max gauge
# HELP jvm_memory_bytes_used Used bytes of a given JVM memory area.
# TYPE jvm_memory_bytes_used gauge
# HELP jvm_memory_pool_bytes_committed Committed bytes of a given JVM memory pool.
# TYPE jvm_memory_pool_bytes_committed gauge
# HELP jvm_memory_pool_bytes_init Initial bytes of a given JVM memory pool.
# TYPE jvm_memory_pool_bytes_init gauge
# HELP jvm_memory_pool_bytes_max Max bytes of a given JVM memory pool.
# TYPE jvm_memory_pool_bytes_max gauge
# HELP jvm_memory_pool_bytes_used Used bytes of a given JVM memory pool.
# TYPE jvm_memory_pool_bytes_used gauge
# HELP jvm_threads_current Current thread count of a JVM
# TYPE jvm_threads_current gauge
# HELP jvm_threads_daemon Daemon thread count of a JVM
# TYPE jvm_threads_daemon gauge
# HELP jvm_threads_deadlocked Cycles of JVM-threads that are in deadlock waiting to acquire object monitors or ownable synchronizers
# TYPE jvm_threads_deadlocked gauge
# HELP jvm_threads_deadlocked_monitor Cycles of JVM-threads that are in deadlock waiting to acquire object monitors
# TYPE jvm_threads_deadlocked_monitor gauge
# HELP jvm_threads_peak Peak thread count of a JVM
# TYPE jvm_threads_peak gauge
# HELP jvm_threads_started_total Started thread count of a JVM
# TYPE jvm_threads_started_total counter
# HELP jvm_threads_state Current count of threads by state
# TYPE jvm_threads_state gauge
# HELP process_cpu_seconds_total Total user and system CPU time spent in seconds.
# TYPE process_cpu_seconds_total counter
# HELP process_max_fds Maximum number of open file descriptors.
# TYPE process_max_fds gauge
# HELP process_open_fds Number of open file descriptors.
# TYPE process_open_fds gauge
# HELP process_start_time_seconds Start time of the process since unix epoch in seconds.
# TYPE process_start_time_seconds gauge
# HELP rocksdb_block_cache_add RocksDB reported statistics for BLOCK_CACHE_ADD
# TYPE rocksdb_block_cache_add gauge
# HELP rocksdb_block_cache_add_failures RocksDB reported statistics for BLOCK_CACHE_ADD_FAILURES
# TYPE rocksdb_block_cache_add_failures gauge
# HELP rocksdb_block_cache_bytes_read RocksDB reported statistics for BLOCK_CACHE_BYTES_READ
# TYPE rocksdb_block_cache_bytes_read gauge
# HELP rocksdb_block_cache_bytes_write RocksDB reported statistics for BLOCK_CACHE_BYTES_WRITE
# TYPE rocksdb_block_cache_bytes_write gauge
# HELP rocksdb_block_cache_compressed_add RocksDB reported statistics for BLOCK_CACHE_COMPRESSED_ADD
# TYPE rocksdb_block_cache_compressed_add gauge
# HELP rocksdb_block_cache_compressed_add_failures RocksDB reported statistics for BLOCK_CACHE_COMPRESSED_ADD_FAILURES
# TYPE rocksdb_block_cache_compressed_add_failures gauge
# HELP rocksdb_block_cache_compressed_hit RocksDB reported statistics for BLOCK_CACHE_COMPRESSED_HIT
# TYPE rocksdb_block_cache_compressed_hit gauge
# HELP rocksdb_block_cache_compressed_miss RocksDB reported statistics for BLOCK_CACHE_COMPRESSED_MISS
# TYPE rocksdb_block_cache_compressed_miss gauge
# HELP rocksdb_block_cache_data_add RocksDB reported statistics for BLOCK_CACHE_DATA_ADD
# TYPE rocksdb_block_cache_data_add gauge
# HELP rocksdb_block_cache_data_bytes_insert RocksDB reported statistics for BLOCK_CACHE_DATA_BYTES_INSERT
# TYPE rocksdb_block_cache_data_bytes_insert gauge
# HELP rocksdb_block_cache_data_hit RocksDB reported statistics for BLOCK_CACHE_DATA_HIT
# TYPE rocksdb_block_cache_data_hit gauge
# HELP rocksdb_block_cache_data_miss RocksDB reported statistics for BLOCK_CACHE_DATA_MISS
# TYPE rocksdb_block_cache_data_miss gauge
# HELP rocksdb_block_cache_filter_add RocksDB reported statistics for BLOCK_CACHE_FILTER_ADD
# TYPE rocksdb_block_cache_filter_add gauge
# HELP rocksdb_block_cache_filter_bytes_evict RocksDB reported statistics for BLOCK_CACHE_FILTER_BYTES_EVICT
# TYPE rocksdb_block_cache_filter_bytes_evict gauge
# HELP rocksdb_block_cache_filter_bytes_insert RocksDB reported statistics for BLOCK_CACHE_FILTER_BYTES_INSERT
# TYPE rocksdb_block_cache_filter_bytes_insert gauge
# HELP rocksdb_block_cache_filter_hit RocksDB reported statistics for BLOCK_CACHE_FILTER_HIT
# TYPE rocksdb_block_cache_filter_hit gauge
# HELP rocksdb_block_cache_filter_miss RocksDB reported statistics for BLOCK_CACHE_FILTER_MISS
# TYPE rocksdb_block_cache_filter_miss gauge
# HELP rocksdb_block_cache_hit RocksDB reported statistics for BLOCK_CACHE_HIT
# TYPE rocksdb_block_cache_hit gauge
# HELP rocksdb_block_cache_index_add RocksDB reported statistics for BLOCK_CACHE_INDEX_ADD
# TYPE rocksdb_block_cache_index_add gauge
# HELP rocksdb_block_cache_index_bytes_evict RocksDB reported statistics for BLOCK_CACHE_INDEX_BYTES_EVICT
# TYPE rocksdb_block_cache_index_bytes_evict gauge
# HELP rocksdb_block_cache_index_bytes_insert RocksDB reported statistics for BLOCK_CACHE_INDEX_BYTES_INSERT
# TYPE rocksdb_block_cache_index_bytes_insert gauge
# HELP rocksdb_block_cache_index_hit RocksDB reported statistics for BLOCK_CACHE_INDEX_HIT
# TYPE rocksdb_block_cache_index_hit gauge
# HELP rocksdb_block_cache_index_miss RocksDB reported statistics for BLOCK_CACHE_INDEX_MISS
# TYPE rocksdb_block_cache_index_miss gauge
# HELP rocksdb_bloom_filter_prefix_checked RocksDB reported statistics for BLOOM_FILTER_PREFIX_CHECKED
# TYPE rocksdb_bloom_filter_prefix_checked gauge
# HELP rocksdb_bloom_filter_prefix_useful RocksDB reported statistics for BLOOM_FILTER_PREFIX_USEFUL
# TYPE rocksdb_bloom_filter_prefix_useful gauge
# HELP rocksdb_bloom_filter_useful RocksDB reported statistics for BLOOM_FILTER_USEFUL
# TYPE rocksdb_bloom_filter_useful gauge
# HELP rocksdb_bytes_compressed RocksDB histogram for rocksdb_bytes_compressed
# TYPE rocksdb_bytes_compressed summary
# HELP rocksdb_bytes_decompressed RocksDB histogram for rocksdb_bytes_decompressed
# TYPE rocksdb_bytes_decompressed summary
# HELP rocksdb_bytes_per_multiget RocksDB histogram for rocksdb_bytes_per_multiget
# TYPE rocksdb_bytes_per_multiget summary
# HELP rocksdb_bytes_per_read RocksDB histogram for rocksdb_bytes_per_read
# TYPE rocksdb_bytes_per_read summary
# HELP rocksdb_bytes_per_write RocksDB histogram for rocksdb_bytes_per_write
# TYPE rocksdb_bytes_per_write summary
# HELP rocksdb_bytes_read RocksDB reported statistics for BYTES_READ
# TYPE rocksdb_bytes_read gauge
# HELP rocksdb_bytes_written RocksDB reported statistics for BYTES_WRITTEN
# TYPE rocksdb_bytes_written gauge
# HELP rocksdb_compact_read_bytes RocksDB reported statistics for COMPACT_READ_BYTES
# TYPE rocksdb_compact_read_bytes gauge
# HELP rocksdb_compact_write_bytes RocksDB reported statistics for COMPACT_WRITE_BYTES
# TYPE rocksdb_compact_write_bytes gauge
# HELP rocksdb_compaction_key_drop_newer_entry RocksDB reported statistics for COMPACTION_KEY_DROP_NEWER_ENTRY
# TYPE rocksdb_compaction_key_drop_newer_entry gauge
# HELP rocksdb_compaction_key_drop_obsolete RocksDB reported statistics for COMPACTION_KEY_DROP_OBSOLETE
# TYPE rocksdb_compaction_key_drop_obsolete gauge
# HELP rocksdb_compaction_key_drop_range_del RocksDB reported statistics for COMPACTION_KEY_DROP_RANGE_DEL
# TYPE rocksdb_compaction_key_drop_range_del gauge
# HELP rocksdb_compaction_key_drop_user RocksDB reported statistics for COMPACTION_KEY_DROP_USER
# TYPE rocksdb_compaction_key_drop_user gauge
# HELP rocksdb_compaction_outfile_sync_micros RocksDB histogram for rocksdb_compaction_outfile_sync_micros
# TYPE rocksdb_compaction_outfile_sync_micros summary
# HELP rocksdb_compaction_range_del_drop_obsolete RocksDB reported statistics for COMPACTION_RANGE_DEL_DROP_OBSOLETE
# TYPE rocksdb_compaction_range_del_drop_obsolete gauge
# HELP rocksdb_compaction_time RocksDB histogram for rocksdb_compaction_time
# TYPE rocksdb_compaction_time summary
# HELP rocksdb_compression_times_nanos RocksDB histogram for rocksdb_compression_times_nanos
# TYPE rocksdb_compression_times_nanos summary
# HELP rocksdb_db_get RocksDB histogram for rocksdb_db_get
# TYPE rocksdb_db_get summary
# HELP rocksdb_db_multiget RocksDB histogram for rocksdb_db_multiget
# TYPE rocksdb_db_multiget summary
# HELP rocksdb_db_mutex_wait_micros RocksDB reported statistics for DB_MUTEX_WAIT_MICROS
# TYPE rocksdb_db_mutex_wait_micros gauge
# HELP rocksdb_db_seek RocksDB histogram for rocksdb_db_seek
# TYPE rocksdb_db_seek summary
# HELP rocksdb_db_write RocksDB histogram for rocksdb_db_write
# TYPE rocksdb_db_write summary
# HELP rocksdb_decompression_times_nanos RocksDB histogram for rocksdb_decompression_times_nanos
# TYPE rocksdb_decompression_times_nanos summary
# HELP rocksdb_filter_operation_total_time RocksDB reported statistics for FILTER_OPERATION_TOTAL_TIME
# TYPE rocksdb_filter_operation_total_time gauge
# HELP rocksdb_flush_write_bytes RocksDB reported statistics for FLUSH_WRITE_BYTES
# TYPE rocksdb_flush_write_bytes gauge
# HELP rocksdb_get_hit_l0 RocksDB reported statistics for GET_HIT_L0
# TYPE rocksdb_get_hit_l0 gauge
# HELP rocksdb_get_hit_l1 RocksDB reported statistics for GET_HIT_L1
# TYPE rocksdb_get_hit_l1 gauge
# HELP rocksdb_get_hit_l2_and_up RocksDB reported statistics for GET_HIT_L2_AND_UP
# TYPE rocksdb_get_hit_l2_and_up gauge
# HELP rocksdb_get_updates_since_calls RocksDB reported statistics for GET_UPDATES_SINCE_CALLS
# TYPE rocksdb_get_updates_since_calls gauge
# HELP rocksdb_hard_rate_limit_delay_count RocksDB histogram for rocksdb_hard_rate_limit_delay_count
# TYPE rocksdb_hard_rate_limit_delay_count summary
# HELP rocksdb_iter_bytes_read RocksDB reported statistics for ITER_BYTES_READ
# TYPE rocksdb_iter_bytes_read gauge
# HELP rocksdb_manifest_file_sync_micros RocksDB histogram for rocksdb_manifest_file_sync_micros
# TYPE rocksdb_manifest_file_sync_micros summary
# HELP rocksdb_memtable_hit RocksDB reported statistics for MEMTABLE_HIT
# TYPE rocksdb_memtable_hit gauge
# HELP rocksdb_memtable_miss RocksDB reported statistics for MEMTABLE_MISS
# TYPE rocksdb_memtable_miss gauge
# HELP rocksdb_merge_operation_total_time RocksDB reported statistics for MERGE_OPERATION_TOTAL_TIME
# TYPE rocksdb_merge_operation_total_time gauge
# HELP rocksdb_no_file_closes RocksDB reported statistics for NO_FILE_CLOSES
# TYPE rocksdb_no_file_closes gauge
# HELP rocksdb_no_file_errors RocksDB reported statistics for NO_FILE_ERRORS
# TYPE rocksdb_no_file_errors gauge
# HELP rocksdb_no_file_opens RocksDB reported statistics for NO_FILE_OPENS
# TYPE rocksdb_no_file_opens gauge
# HELP rocksdb_no_iterators RocksDB reported statistics for NO_ITERATORS
# TYPE rocksdb_no_iterators gauge
# HELP rocksdb_num_files_in_single_compaction RocksDB histogram for rocksdb_num_files_in_single_compaction
# TYPE rocksdb_num_files_in_single_compaction summary
# HELP rocksdb_num_subcompactions_scheduled RocksDB histogram for rocksdb_num_subcompactions_scheduled
# TYPE rocksdb_num_subcompactions_scheduled summary
# HELP rocksdb_number_block_compressed RocksDB reported statistics for NUMBER_BLOCK_COMPRESSED
# TYPE rocksdb_number_block_compressed gauge
# HELP rocksdb_number_block_decompressed RocksDB reported statistics for NUMBER_BLOCK_DECOMPRESSED
# TYPE rocksdb_number_block_decompressed gauge
# HELP rocksdb_number_block_not_compressed RocksDB reported statistics for NUMBER_BLOCK_NOT_COMPRESSED
# TYPE rocksdb_number_block_not_compressed gauge
# HELP rocksdb_number_db_next RocksDB reported statistics for NUMBER_DB_NEXT
# TYPE rocksdb_number_db_next gauge
# HELP rocksdb_number_db_next_found RocksDB reported statistics for NUMBER_DB_NEXT_FOUND
# TYPE rocksdb_number_db_next_found gauge
# HELP rocksdb_number_db_prev RocksDB reported statistics for NUMBER_DB_PREV
# TYPE rocksdb_number_db_prev gauge
# HELP rocksdb_number_db_prev_found RocksDB reported statistics for NUMBER_DB_PREV_FOUND
# TYPE rocksdb_number_db_prev_found gauge
# HELP rocksdb_number_db_seek RocksDB reported statistics for NUMBER_DB_SEEK
# TYPE rocksdb_number_db_seek gauge
# HELP rocksdb_number_db_seek_found RocksDB reported statistics for NUMBER_DB_SEEK_FOUND
# TYPE rocksdb_number_db_seek_found gauge
# HELP rocksdb_number_direct_load_table_properties RocksDB reported statistics for NUMBER_DIRECT_LOAD_TABLE_PROPERTIES
# TYPE rocksdb_number_direct_load_table_properties gauge
# HELP rocksdb_number_filtered_deletes RocksDB reported statistics for NUMBER_FILTERED_DELETES
# TYPE rocksdb_number_filtered_deletes gauge
# HELP rocksdb_number_iter_skip RocksDB reported statistics for NUMBER_ITER_SKIP
# TYPE rocksdb_number_iter_skip gauge
# HELP rocksdb_number_keys_read RocksDB reported statistics for NUMBER_KEYS_READ
# TYPE rocksdb_number_keys_read gauge
# HELP rocksdb_number_keys_updated RocksDB reported statistics for NUMBER_KEYS_UPDATED
# TYPE rocksdb_number_keys_updated gauge
# HELP rocksdb_number_keys_written RocksDB reported statistics for NUMBER_KEYS_WRITTEN
# TYPE rocksdb_number_keys_written gauge
# HELP rocksdb_number_merge_failures RocksDB reported statistics for NUMBER_MERGE_FAILURES
# TYPE rocksdb_number_merge_failures gauge
# HELP rocksdb_number_multiget_bytes_read RocksDB reported statistics for NUMBER_MULTIGET_BYTES_READ
# TYPE rocksdb_number_multiget_bytes_read gauge
# HELP rocksdb_number_multiget_calls RocksDB reported statistics for NUMBER_MULTIGET_CALLS
# TYPE rocksdb_number_multiget_calls gauge
# HELP rocksdb_number_multiget_keys_found RocksDB reported statistics for NUMBER_MULTIGET_KEYS_FOUND
# TYPE rocksdb_number_multiget_keys_found gauge
# HELP rocksdb_number_multiget_keys_read RocksDB reported statistics for NUMBER_MULTIGET_KEYS_READ
# TYPE rocksdb_number_multiget_keys_read gauge
# HELP rocksdb_number_of_reseeks_in_iteration RocksDB reported statistics for NUMBER_OF_RESEEKS_IN_ITERATION
# TYPE rocksdb_number_of_reseeks_in_iteration gauge
# HELP rocksdb_number_rate_limiter_drains RocksDB reported statistics for NUMBER_RATE_LIMITER_DRAINS
# TYPE rocksdb_number_rate_limiter_drains gauge
# HELP rocksdb_number_superversion_acquires RocksDB reported statistics for NUMBER_SUPERVERSION_ACQUIRES
# TYPE rocksdb_number_superversion_acquires gauge
# HELP rocksdb_number_superversion_cleanups RocksDB reported statistics for NUMBER_SUPERVERSION_CLEANUPS
# TYPE rocksdb_number_superversion_cleanups gauge
# HELP rocksdb_number_superversion_releases RocksDB reported statistics for NUMBER_SUPERVERSION_RELEASES
# TYPE rocksdb_number_superversion_releases gauge
# HELP rocksdb_persistent_cache_hit RocksDB reported statistics for PERSISTENT_CACHE_HIT
# TYPE rocksdb_persistent_cache_hit gauge
# HELP rocksdb_persistent_cache_miss RocksDB reported statistics for PERSISTENT_CACHE_MISS
# TYPE rocksdb_persistent_cache_miss gauge
# HELP rocksdb_rate_limit_delay_millis RocksDB reported statistics for RATE_LIMIT_DELAY_MILLIS
# TYPE rocksdb_rate_limit_delay_millis gauge
# HELP rocksdb_read_amp_estimate_useful_bytes RocksDB reported statistics for READ_AMP_ESTIMATE_USEFUL_BYTES
# TYPE rocksdb_read_amp_estimate_useful_bytes gauge
# HELP rocksdb_read_amp_total_read_bytes RocksDB reported statistics for READ_AMP_TOTAL_READ_BYTES
# TYPE rocksdb_read_amp_total_read_bytes gauge
# HELP rocksdb_read_block_compaction_micros RocksDB histogram for rocksdb_read_block_compaction_micros
# TYPE rocksdb_read_block_compaction_micros summary
# HELP rocksdb_read_block_get_micros RocksDB histogram for rocksdb_read_block_get_micros
# TYPE rocksdb_read_block_get_micros summary
# HELP rocksdb_read_num_merge_operands RocksDB histogram for rocksdb_read_num_merge_operands
# TYPE rocksdb_read_num_merge_operands summary
# HELP rocksdb_row_cache_hit RocksDB reported statistics for ROW_CACHE_HIT
# TYPE rocksdb_row_cache_hit gauge
# HELP rocksdb_row_cache_miss RocksDB reported statistics for ROW_CACHE_MISS
# TYPE rocksdb_row_cache_miss gauge
# HELP rocksdb_sim_block_cache_hit RocksDB reported statistics for SIM_BLOCK_CACHE_HIT
# TYPE rocksdb_sim_block_cache_hit gauge
# HELP rocksdb_sim_block_cache_miss RocksDB reported statistics for SIM_BLOCK_CACHE_MISS
# TYPE rocksdb_sim_block_cache_miss gauge
# HELP rocksdb_soft_rate_limit_delay_count RocksDB histogram for rocksdb_soft_rate_limit_delay_count
# TYPE rocksdb_soft_rate_limit_delay_count summary
# HELP rocksdb_sst_read_micros RocksDB histogram for rocksdb_sst_read_micros
# TYPE rocksdb_sst_read_micros summary
# HELP rocksdb_stall_l0_num_files_count RocksDB histogram for rocksdb_stall_l0_num_files_count
# TYPE rocksdb_stall_l0_num_files_count summary
# HELP rocksdb_stall_l0_slowdown_count RocksDB histogram for rocksdb_stall_l0_slowdown_count
# TYPE rocksdb_stall_l0_slowdown_count summary
# HELP rocksdb_stall_memtable_compaction_count RocksDB histogram for rocksdb_stall_memtable_compaction_count
# TYPE rocksdb_stall_memtable_compaction_count summary
# HELP rocksdb_stall_micros RocksDB reported statistics for STALL_MICROS
# TYPE rocksdb_stall_micros gauge
# HELP rocksdb_subcompaction_setup_time RocksDB histogram for rocksdb_subcompaction_setup_time
# TYPE rocksdb_subcompaction_setup_time summary
# HELP rocksdb_table_open_io_micros RocksDB histogram for rocksdb_table_open_io_micros
# TYPE rocksdb_table_open_io_micros summary
# HELP rocksdb_table_sync_micros RocksDB histogram for rocksdb_table_sync_micros
# TYPE rocksdb_table_sync_micros summary
# HELP rocksdb_wal_file_bytes RocksDB reported statistics for WAL_FILE_BYTES
# TYPE rocksdb_wal_file_bytes gauge
# HELP rocksdb_wal_file_sync_micros RocksDB histogram for rocksdb_wal_file_sync_micros
# TYPE rocksdb_wal_file_sync_micros summary
# HELP rocksdb_wal_file_synced RocksDB reported statistics for WAL_FILE_SYNCED
# TYPE rocksdb_wal_file_synced gauge
# HELP rocksdb_write_done_by_other RocksDB reported statistics for WRITE_DONE_BY_OTHER
# TYPE rocksdb_write_done_by_other gauge
# HELP rocksdb_write_done_by_self RocksDB reported statistics for WRITE_DONE_BY_SELF
# TYPE rocksdb_write_done_by_self gauge
# HELP rocksdb_write_raw_block_micros RocksDB histogram for rocksdb_write_raw_block_micros
# TYPE rocksdb_write_raw_block_micros summary
# HELP rocksdb_write_stall RocksDB histogram for rocksdb_write_stall
# TYPE rocksdb_write_stall summary
# HELP rocksdb_write_timedout RocksDB reported statistics for WRITE_TIMEDOUT
# TYPE rocksdb_write_timedout gauge
# HELP rocksdb_write_with_wal RocksDB reported statistics for WRITE_WITH_WAL
# TYPE rocksdb_write_with_wal gauge
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment