meshcloud

meshcloud

  • User Docs
  • Operator Docs
  • API Docs
  • Release Notes
  • FAQ
  • Help
  • Feedback

›Operations

Governance

  • Overview
  • meshTenants
  • Replication Configuration
  • Managing Tags
  • Identifiers
  • Onboarding
  • Customizing
  • meshStack APIs

Identity & Access

  • Identity and Access Management
  • Identity Provider
  • Identity Lookup
  • Authorization
  • User Revocation
  • User & Group LDAP Synchronisation
  • User & Group SCIM Synchronisation

Metering & Billing

  • Architecture
  • Configuration

Amazon Web Services

  • Integration
  • Landing Zones
  • Metering
  • SSO Setup
  • Reserved Instances & Savings Plans Guide

Microsoft Azure

  • Integration
  • Landing Zones
  • Metering
  • Cloud Inventory

Google Cloud Platform

  • Integration
  • Landing Zones
  • Metering

Cloud Foundry

  • Integration
  • Metering

Kubernetes

  • Integration
  • Landing Zones
  • Metering

OpenShift

  • Integration
  • Landing Zones
  • Metering

OpenStack

  • Integration
  • VMware Integrated OpenStack
  • Metering
  • Cloud Inventory

meshMarketplace

  • Integration
  • Marketplace Development
  • Metering
  • meshcloud OSB API Profile
  • Tenant Services
  • Metrics-based Metering
  • Tutorial: Implement a Broker
  • Tutorial: Dashboards

Operations

  • Managed Service
  • Email
  • Logging & Auditing
  • Metrics & Monitoring
  • Metrics Metadata
  • Backup

Guides

  • How to get started with meshStack
  • How to integrate a meshPlatform into meshStack
  • How to manually integrate AWS as meshPlatform
  • How to manually integrate Azure as meshPlatform
  • How to manually integrate GCP as meshPlatform
  • How to create a meshCustomer via API
  • How to start with the meshMarketplace
  • How to manage partner level permissions
Edit

Metrics Metadata

Prometheus exposes /api/v1/metadata endpoint that shows metadata (name and description) of currently scraped metrics. The metadata is rendered in the table below.

A few metrics do not have a description. To clarify specific metrics description, please contact us.

MetricDescription
accessProject_total
backup_statusIndicates success/failure of the last backup attempt.
backup_time_secondsLast Unix time when this source was backed up.
cortex_cache_corrupt_chunksTotal count of corrupt chunks found in cache.
cortex_chunk_store_chunks_per_queryDistribution of #chunks per query.
cortex_chunk_store_deduped_chunksCount of chunks which were not stored because they have already been stored by another replica.
cortex_chunk_store_fetched_chunk_bytesTotal bytes fetched in chunks per user.
cortex_chunk_store_fetched_chunksTotal fetched chunks per user.
cortex_chunk_store_index_entries_per_chunkNumber of entries written to storage per chunk.
cortex_chunk_store_index_lookups_per_queryDistribution of #index lookups per query.
cortex_chunk_store_series_post_intersection_per_queryDistribution of #series (post intersection) per query.
cortex_chunk_store_series_pre_intersection_per_queryDistribution of #series (pre intersection) per query.
cortex_chunk_store_stored_chunk_bytesTotal bytes stored in chunks per user.
cortex_chunk_store_stored_chunksTotal stored chunks per user.
cortex_consul_request_duration_secondsTime spent on consul requests.
cortex_deprecated_flags_inuseThe number of deprecated flags currently set.
cortex_distributor_ingester_clientsThe current number of ingester clients.
cortex_experimental_features_in_useThe number of experimental features in use.
cortex_ingester_flush_queue_lengthThe total number of series pending in the flush queue.
cortex_kv_request_duration_secondsTime spent on kv store requests.
cortex_member_consul_heartbeatsThe total number of heartbeats sent to consul.
cortex_member_ring_tokens_ownedThe number of tokens owned in the ring.
cortex_member_ring_tokens_to_ownThe number of tokens to own in the ring.
cortex_multikv_mirror_enabledIs mirroring to secondary store enabled
cortex_multikv_mirror_write_errorsNumber of failures to mirror-write to secondary store
cortex_multikv_mirror_writesNumber of mirror-writes to secondary store
cortex_ring_member_ownership_percentThe percent ownership of the ring by member
cortex_ring_membersNumber of members in the ring
cortex_ring_oldest_member_timestampTimestamp of the oldest member in the ring.
cortex_ring_tokens_ownedThe number of tokens in the ring owned by the member
cortex_ring_tokens_totalNumber of tokens in the ring
cortex_table_capacity_unitsPer-table capacity, measured in DynamoDB capacity units.
cortex_table_manager_create_failuresNumber of table creation failures during the last table-manager reconciliation
cortex_table_manager_delete_failuresNumber of table deletion failures during the last table-manager reconciliation
cortex_table_manager_sync_duration_secondsTime spent synching tables.
cortex_table_manager_sync_success_timestamp_secondsTimestamp of the last successful table manager sync.
erlang_mnesia_committed_transactionsNumber of committed transactions.
erlang_mnesia_failed_transactionsNumber of failed (i.e. aborted) transactions.
erlang_mnesia_held_locksNumber of held locks.
erlang_mnesia_lock_queueNumber of transactions waiting for a lock.
erlang_mnesia_logged_transactionsNumber of transactions logged.
erlang_mnesia_memory_usage_bytesTotal number of bytes allocated by all mnesia tables
erlang_mnesia_restarted_transactionsTotal number of transaction restarts.
erlang_mnesia_tablewise_memory_usage_bytesNumber of bytes allocated per mnesia table
erlang_mnesia_tablewise_sizeNumber of rows present per table
erlang_mnesia_transaction_coordinatorsNumber of coordinator transactions.
erlang_mnesia_transaction_participantsNumber of participant transactions.
erlang_vm_allocatorsAllocated (carriers_size) and used (blocks_size) memory for the different allocators in the VM. See erts_alloc(3).
erlang_vm_atom_countThe number of atom currently existing at the local node.
erlang_vm_atom_limitThe maximum number of simultaneously existing atom at the local node.
erlang_vm_dirty_cpu_schedulersThe number of scheduler dirty CPU scheduler threads used by the emulator.
erlang_vm_dirty_cpu_schedulers_onlineThe number of dirty CPU scheduler threads online.
erlang_vm_dirty_io_schedulersThe number of scheduler dirty I/O scheduler threads used by the emulator.
erlang_vm_dist_node_queue_size_bytesThe number of bytes in the output distribution queue. This queue sits between the Erlang code and the port driver.
erlang_vm_dist_node_stateThe current state of the distribution link. The state is represented as a numerical value where pending=1, up_pending=2 and up=3.
erlang_vm_dist_port_input_bytesThe total number of bytes read from the port.
erlang_vm_dist_port_memory_bytesThe total number of bytes allocated for this port by the runtime system. The port itself can have allocated memory that is not included.
erlang_vm_dist_port_output_bytesThe total number of bytes written to the port.
erlang_vm_dist_port_queue_size_bytesThe total number of bytes queued by the port using the ERTS driver queue implementation.
erlang_vm_dist_proc_heap_size_wordsThe size in words of the youngest heap generation of the process. This generation includes the process stack. This information is highly implementation-dependent, and can change if the implementation changes.
erlang_vm_dist_proc_memory_bytesThe size in bytes of the process. This includes call stack, heap, and internal structures.
erlang_vm_dist_proc_message_queue_lenThe number of messages currently in the message queue of the process.
erlang_vm_dist_proc_min_bin_vheap_size_wordsThe minimum binary virtual heap size for the process.
erlang_vm_dist_proc_min_heap_size_wordsThe minimum heap size for the process.
erlang_vm_dist_proc_reductionsThe number of reductions executed by the process.
erlang_vm_dist_proc_stack_size_wordsThe stack size, in words, of the process.
erlang_vm_dist_proc_statusThe current status of the distribution process. The status is represented as a numerical value where exiting=1, suspended=2, runnable=3, garbage_collecting=4, running=5 and waiting=6.
erlang_vm_dist_proc_total_heap_size_wordsThe total size, in words, of all heap fragments of the process. This includes the process stack and any unreceived messages that are considered to be part of the heap.
erlang_vm_dist_recv_avg_bytesAverage size of packets, in bytes, received by the socket.
erlang_vm_dist_recv_bytesNumber of bytes received by the socket.
erlang_vm_dist_recv_cntNumber of packets received by the socket.
erlang_vm_dist_recv_dvi_bytesAverage packet size deviation, in bytes, received by the socket.
erlang_vm_dist_recv_max_bytesSize of the largest packet, in bytes, received by the socket.
erlang_vm_dist_send_avg_bytesAverage size of packets, in bytes, sent from the socket.
erlang_vm_dist_send_bytesNumber of bytes sent from the socket.
erlang_vm_dist_send_cntNumber of packets sent from the socket.
erlang_vm_dist_send_max_bytesSize of the largest packet, in bytes, sent from the socket.
erlang_vm_dist_send_pend_bytesNumber of bytes waiting to be sent by the socket.
erlang_vm_ets_limitThe maximum number of ETS tables allowed.
erlang_vm_logical_processorsThe detected number of logical processors configured in the system.
erlang_vm_logical_processors_availableThe detected number of logical processors available to the Erlang runtime system.
erlang_vm_logical_processors_onlineThe detected number of logical processors online on the system.
erlang_vm_memory_atom_bytes_totalThe total amount of memory currently allocated for atoms. This memory is part of the memory presented as system memory.
erlang_vm_memory_bytes_totalThe total amount of memory currently allocated. This is the same as the sum of the memory size for processes and system.
erlang_vm_memory_dets_tablesErlang VM DETS Tables count.
erlang_vm_memory_ets_tablesErlang VM ETS Tables count.
erlang_vm_memory_processes_bytes_totalThe total amount of memory currently allocated for the Erlang processes.
erlang_vm_memory_system_bytes_totalThe total amount of memory currently allocated for the emulator that is not directly related to any Erlang process. Memory presented as processes is not included in this memory.
erlang_vm_msacc_alloc_seconds_totalTotal time in seconds spent managing memory. Without extra states this time is spread out over all other states.
erlang_vm_msacc_aux_seconds_totalTotal time in seconds spent handling auxiliary jobs.
erlang_vm_msacc_bif_seconds_totalTotal time in seconds spent in BIFs. Without extra states this time is part of the 'emulator' state.
erlang_vm_msacc_busy_wait_seconds_totalTotal time in seconds spent busy waiting. Without extra states this time is part of the 'other' state.
erlang_vm_msacc_check_io_seconds_totalTotal time in seconds spent checking for new I/O events.
erlang_vm_msacc_emulator_seconds_totalTotal time in seconds spent executing Erlang processes.
erlang_vm_msacc_ets_seconds_totalTotal time in seconds spent executing ETS BIFs. Without extra states this time is part of the 'emulator' state.
erlang_vm_msacc_gc_full_seconds_totalTotal time in seconds spent doing fullsweep garbage collection. Without extra states this time is part of the 'gc' state.
erlang_vm_msacc_gc_seconds_totalTotal time in seconds spent doing garbage collection. When extra states are enabled this is the time spent doing non-fullsweep garbage collections.
erlang_vm_msacc_nif_seconds_totalTotal time in seconds spent in NIFs. Without extra states this time is part of the 'emulator' state.
erlang_vm_msacc_other_seconds_totalTotal time in seconds spent doing unaccounted things.
erlang_vm_msacc_port_seconds_totalTotal time in seconds spent executing ports.
erlang_vm_msacc_send_seconds_totalTotal time in seconds spent sending messages (processes only). Without extra states this time is part of the 'emulator' state.
erlang_vm_msacc_sleep_seconds_totalTotal time in seconds spent sleeping.
erlang_vm_msacc_timers_seconds_totalTotal time in seconds spent managing timers. Without extra states this time is part of the 'other' state.
erlang_vm_port_countThe number of ports currently existing at the local node.
erlang_vm_port_limitThe maximum number of simultaneously existing ports at the local node.
erlang_vm_process_countThe number of processes currently existing at the local node.
erlang_vm_process_limitThe maximum number of simultaneously existing processes at the local node.
erlang_vm_schedulersThe number of scheduler threads used by the emulator.
erlang_vm_schedulers_onlineThe number of schedulers online.
erlang_vm_smp_support1 if the emulator has been compiled with SMP support, otherwise 0.
erlang_vm_statistics_bytes_output_totalTotal number of bytes output to ports.
erlang_vm_statistics_bytes_received_totalTotal number of bytes received through ports.
erlang_vm_statistics_context_switchesTotal number of context switches since the system started.
erlang_vm_statistics_dirty_cpu_run_queue_lengthLength of the dirty CPU run-queue.
erlang_vm_statistics_dirty_io_run_queue_lengthLength of the dirty IO run-queue.
erlang_vm_statistics_garbage_collection_bytes_reclaimedGarbage collection: bytes reclaimed.
erlang_vm_statistics_garbage_collection_number_of_gcsGarbage collection: number of GCs.
erlang_vm_statistics_garbage_collection_words_reclaimedGarbage collection: words reclaimed.
erlang_vm_statistics_reductions_totalTotal reductions.
erlang_vm_statistics_run_queues_length_totalLength of normal run-queues.
erlang_vm_statistics_runtime_millisecondsThe sum of the runtime for all threads in the Erlang runtime system. Can be greater than wall clock time.
erlang_vm_statistics_wallclock_time_millisecondsInformation about wall clock. Same as erlang_vm_statistics_runtime_milliseconds except that real time is measured.
erlang_vm_thread_pool_sizeThe number of async threads in the async thread pool used for asynchronous driver calls.
erlang_vm_threads1 if the emulator has been compiled with thread support, otherwise 0.
erlang_vm_time_correction1 if time correction is enabled, otherwise 0.
erlang_vm_wordsize_bytesThe size of Erlang term words in bytes.
etcd_debugging_auth_revisionThe current revision of auth store.
etcd_debugging_disk_backend_commit_rebalance_duration_secondsThe latency distributions of commit.rebalance called by bboltdb backend.
etcd_debugging_disk_backend_commit_spill_duration_secondsThe latency distributions of commit.spill called by bboltdb backend.
etcd_debugging_disk_backend_commit_write_duration_secondsThe latency distributions of commit.write called by bboltdb backend.
etcd_debugging_lease_grantedThe total number of granted leases.
etcd_debugging_lease_renewedThe number of renewed leases seen by the leader.
etcd_debugging_lease_revokedThe total number of revoked leases.
etcd_debugging_lease_ttl_totalBucketed histogram of lease TTLs.
etcd_debugging_mvcc_compact_revisionThe revision of the last compaction in store.
etcd_debugging_mvcc_current_revisionThe current revision of store.
etcd_debugging_mvcc_db_compaction_keysTotal number of db keys compacted.
etcd_debugging_mvcc_db_compaction_lastThe unix time of the last db compaction. Resets to 0 on start.
etcd_debugging_mvcc_db_compaction_pause_duration_millisecondsBucketed histogram of db compaction pause duration.
etcd_debugging_mvcc_db_compaction_total_duration_millisecondsBucketed histogram of db compaction total duration.
etcd_debugging_mvcc_db_total_size_in_bytesTotal size of the underlying database physically allocated in bytes.
etcd_debugging_mvcc_deleteTotal number of deletes seen by this member.
etcd_debugging_mvcc_eventsTotal number of events sent by this member.
etcd_debugging_mvcc_index_compaction_pause_duration_millisecondsBucketed histogram of index compaction pause duration.
etcd_debugging_mvcc_keys_totalTotal number of keys.
etcd_debugging_mvcc_pending_events_totalTotal number of pending events to be sent.
etcd_debugging_mvcc_putTotal number of puts seen by this member.
etcd_debugging_mvcc_rangeTotal number of ranges seen by this member.
etcd_debugging_mvcc_slow_watcher_totalTotal number of unsynced slow watchers.
etcd_debugging_mvcc_total_put_size_in_bytesThe total size of put kv pairs seen by this member.
etcd_debugging_mvcc_txnTotal number of txns seen by this member.
etcd_debugging_mvcc_watch_stream_totalTotal number of watch streams.
etcd_debugging_mvcc_watcher_totalTotal number of watchers.
etcd_debugging_server_lease_expiredThe total number of expired leases.
etcd_debugging_snap_save_marshalling_duration_secondsThe marshalling cost distributions of save called by snapshot.
etcd_debugging_snap_save_total_duration_secondsThe total latency distributions of save called by snapshot.
etcd_debugging_store_expiresTotal number of expired keys.
etcd_debugging_store_watch_requestsTotal number of incoming watch requests (new or reestablished).
etcd_debugging_store_watchersCount of currently active watchers.
etcd_disk_backend_commit_duration_secondsThe latency distributions of commit called by backend.
etcd_disk_backend_defrag_duration_secondsThe latency distribution of backend defragmentation.
etcd_disk_backend_snapshot_duration_secondsThe latency distribution of backend snapshots.
etcd_disk_wal_fsync_duration_secondsThe latency distributions of fsync called by WAL.
etcd_disk_wal_write_bytes_totalTotal number of bytes written in WAL.
etcd_mvcc_db_open_read_transactionsThe number of currently open read transactions
etcd_mvcc_db_total_size_in_bytesTotal size of the underlying database physically allocated in bytes.
etcd_mvcc_db_total_size_in_use_in_bytesTotal size of the underlying database logically in use in bytes.
etcd_mvcc_deleteTotal number of deletes seen by this member.
etcd_mvcc_hash_duration_secondsThe latency distribution of storage hash operation.
etcd_mvcc_hash_rev_duration_secondsThe latency distribution of storage hash by revision operation.
etcd_mvcc_putTotal number of puts seen by this member.
etcd_mvcc_rangeTotal number of ranges seen by this member.
etcd_mvcc_txnTotal number of txns seen by this member.
etcd_network_client_grpc_received_bytesThe total number of bytes received from grpc clients.
etcd_network_client_grpc_sent_bytesThe total number of bytes sent to grpc clients.
etcd_server_go_versionWhich Go version server is running with. 1 for 'server_go_version' label with current version.
etcd_server_has_leaderWhether or not a leader exists. 1 is existence, 0 is not.
etcd_server_health_failuresThe total number of failed health checks
etcd_server_health_successThe total number of successful health checks
etcd_server_heartbeat_send_failuresThe total number of leader heartbeat send failures (likely overloaded from slow disk).
etcd_server_is_leaderWhether or not this member is a leader. 1 if is, 0 otherwise.
etcd_server_is_learnerWhether or not this member is a learner. 1 if is, 0 otherwise.
etcd_server_leader_changes_seenThe number of leader changes seen.
etcd_server_learner_promote_successesThe total number of successful learner promotions while this member is leader.
etcd_server_proposals_applied_totalThe total number of consensus proposals applied.
etcd_server_proposals_committed_totalThe total number of consensus proposals committed.
etcd_server_proposals_failedThe total number of failed proposals seen.
etcd_server_proposals_pendingThe current number of pending proposals to commit.
etcd_server_quota_backend_bytesCurrent backend storage quota size in bytes.
etcd_server_read_indexes_failedThe total number of failed read indexes seen.
etcd_server_slow_applyThe total number of slow apply requests (likely overloaded from slow disk).
etcd_server_slow_read_indexesThe total number of pending read indexes not in sync with leader's or timed out read index requests.
etcd_server_snapshot_apply_in_progress_total1 if the server is applying the incoming snapshot. 0 if none.
etcd_server_versionWhich version is running. 1 for 'server_version' label with current version.
etcd_snap_db_fsync_duration_secondsThe latency distributions of fsyncing .snap.db file
etcd_snap_db_save_total_duration_secondsThe total latency distributions of v3 snapshot save
etcd_snap_fsync_duration_secondsThe latency distributions of fsync called by snap.
go_gc_duration_secondsA summary of the pause duration of garbage collection cycles.
go_goroutinesNumber of goroutines that currently exist.
go_infoInformation about the Go environment.
go_memstats_alloc_bytesNumber of bytes allocated and still in use.
go_memstats_alloc_bytes_totalTotal number of bytes allocated, even if freed.
go_memstats_buck_hash_sys_bytesNumber of bytes used by the profiling bucket hash table.
go_memstats_freesTotal number of frees.
go_memstats_frees_totalTotal number of frees.
go_memstats_gc_cpu_fractionThe fraction of this program's available CPU time used by the GC since the program started.
go_memstats_gc_sys_bytesNumber of bytes used for garbage collection system metadata.
go_memstats_heap_alloc_bytesNumber of heap bytes allocated and still in use.
go_memstats_heap_idle_bytesNumber of heap bytes waiting to be used.
go_memstats_heap_inuse_bytesNumber of heap bytes that are in use.
go_memstats_heap_objectsNumber of allocated objects.
go_memstats_heap_released_bytesNumber of heap bytes released to OS.
go_memstats_heap_sys_bytesNumber of heap bytes obtained from system.
go_memstats_last_gc_time_secondsNumber of seconds since 1970 of last garbage collection.
go_memstats_lookupsTotal number of pointer lookups.
go_memstats_lookups_totalTotal number of pointer lookups.
go_memstats_mallocsTotal number of mallocs.
go_memstats_mallocs_totalTotal number of mallocs.
go_memstats_mcache_inuse_bytesNumber of bytes in use by mcache structures.
go_memstats_mcache_sys_bytesNumber of bytes used for mcache structures obtained from system.
go_memstats_mspan_inuse_bytesNumber of bytes in use by mspan structures.
go_memstats_mspan_sys_bytesNumber of bytes used for mspan structures obtained from system.
go_memstats_next_gc_bytesNumber of heap bytes when next garbage collection will take place.
go_memstats_other_sys_bytesNumber of bytes used for other system allocations.
go_memstats_stack_inuse_bytesNumber of bytes in use by the stack allocator.
go_memstats_stack_sys_bytesNumber of bytes obtained from system for stack allocator.
go_memstats_sys_bytesNumber of bytes obtained from system.
go_threadsNumber of OS threads created.
http_client_requests_secondsTimer of RestTemplate operation
http_client_requests_seconds_maxTimer of RestTemplate operation
http_server_requests_seconds
http_server_requests_seconds_max
httpcomponents_httpclient_pool_route_connectionsThe number of persistent and leased connections per route.
httpcomponents_httpclient_pool_route_maxThe configured maximum number of allowed persistent connections per route.
httpcomponents_httpclient_pool_route_max_defaultThe configured default maximum number of allowed persistent connections per route.
httpcomponents_httpclient_pool_route_pendingThe number of connection requests being blocked awaiting a free connection for all routes.
httpcomponents_httpclient_pool_total_connectionsThe number of persistent and leased connections for all routes.
httpcomponents_httpclient_pool_total_maxThe configured maximum number of allowed persistent connections for all routes.
httpcomponents_httpclient_pool_total_pendingThe number of connection requests being blocked awaiting a free connection for all routes.
identityconnector_collection_ldap_state_collection_seconds
identityconnector_collection_ldap_state_collection_seconds_max
identityconnector_errors_total
identityconnector_object_import_errors_total
identityconnector_object_import_success_total
identityconnector_success_total
jaeger_tracer_baggage_restrictions_updatesNumber of times baggage restrictions were successfully updated
jaeger_tracer_baggage_truncationsNumber of times baggage was truncated as per baggage restrictions
jaeger_tracer_baggage_updatesNumber of times baggage was successfully written or updated on spans
jaeger_tracer_finished_spansNumber of sampled spans finished by this tracer
jaeger_tracer_reporter_queue_lengthCurrent number of spans in the reporter queue
jaeger_tracer_reporter_spansNumber of spans successfully reported
jaeger_tracer_sampler_queriesNumber of times the Sampler succeeded to retrieve sampling strategy
jaeger_tracer_sampler_updatesNumber of times the Sampler succeeded to retrieve and update sampling strategy
jaeger_tracer_span_context_decoding_errorsNumber of errors decoding tracing context
jaeger_tracer_started_spansNumber of spans started by this tracer as sampled
jaeger_tracer_throttled_debug_spansNumber of times debug spans were throttled
jaeger_tracer_throttler_updatesNumber of times throttler successfully updated
jaeger_tracer_tracesNumber of traces started by this tracer as sampled
jvm_buffer_count_buffersAn estimate of the number of buffers in the pool
jvm_buffer_memory_used_bytesAn estimate of the memory that the Java virtual machine is using for this buffer pool
jvm_buffer_total_capacity_bytesAn estimate of the total capacity of the buffers in this pool
jvm_classes_loaded_classesThe number of classes that are currently loaded in the Java virtual machine
jvm_classes_unloaded_classes_totalThe total number of classes unloaded since the Java virtual machine has started execution
jvm_gc_live_data_size_bytesSize of old generation memory pool after a full GC
jvm_gc_max_data_size_bytesMax size of old generation memory pool
jvm_gc_memory_allocated_bytes_totalIncremented for an increase in the size of the young generation memory pool after one GC to before the next
jvm_gc_memory_promoted_bytes_totalCount of positive increases in the size of the old generation memory pool before GC to after GC
jvm_gc_pause_secondsTime spent in GC pause
jvm_gc_pause_seconds_maxTime spent in GC pause
jvm_memory_committed_bytesThe amount of memory in bytes that is committed for the Java virtual machine to use
jvm_memory_max_bytesThe maximum amount of memory in bytes that can be used for memory management
jvm_memory_used_bytesThe amount of used memory
jvm_threads_daemon_threadsThe current number of live daemon threads
jvm_threads_live_threadsThe current number of live threads including both daemon and non-daemon threads
jvm_threads_peak_threadsThe peak live thread count since the Java virtual machine started or peak was reset
jvm_threads_states_threadsThe current number of threads having NEW state
kraken_api_chargeback_statements_failed
kraken_api_subscription_items_total
kraken_api_subscription_progress_timestamp_seconds
kraken_api_subscription_restarts_total
kraken_api_subscription_retry_total
kraken_platform_monthly_usage_ratio
kraken_platform_projected_monthly_usage_ratio
kraken_unmanaged_tenantsThe number of unmanaged tenants collected by Kraken
kraken_worker_tentacle_azure_failed_subscription_collections
kraken_worker_tentacle_collection_duration_seconds_total
kraken_worker_tentacle_collection_items
kraken_worker_tentacle_collection_items_total
kraken_worker_tentacle_collection_progress_timestamp_seconds
kraken_worker_tentacle_collection_total
kraken_worker_tentacle_enqueued_collections
kraken_worker_tentacle_marketplace_catalog_failed_collections_total
kraken_worker_tentacle_marketplace_catalog_successful_collections_total
kraken_worker_tentacle_subscription_items_total
kraken_worker_tentacle_subscription_progress_timestamp_seconds
kraken_worker_tentacle_subscription_restarts_total
kraken_worker_tentacle_subscription_retry_total
krakenworker_db_subscription_items_total
krakenworker_db_subscription_progress_timestamp_seconds
krakenworker_db_subscription_restarts_total
krakenworker_db_subscription_retry_total
kube_certificatesigningrequest_annotationsKubernetes annotations converted to Prometheus labels.
kube_certificatesigningrequest_cert_lengthLength of the issued cert
kube_certificatesigningrequest_conditionThe number of each certificatesigningrequest condition
kube_certificatesigningrequest_createdUnix creation timestamp
kube_certificatesigningrequest_labelsKubernetes labels converted to Prometheus labels.
kube_configmap_createdUnix creation timestamp
kube_configmap_infoInformation about configmap.
kube_configmap_metadata_resource_versionResource version representing a specific version of the configmap.
kube_cronjob_annotationsKubernetes annotations converted to Prometheus labels.
kube_cronjob_createdUnix creation timestamp
kube_cronjob_infoInfo about cronjob.
kube_cronjob_labelsKubernetes labels converted to Prometheus labels.
kube_cronjob_metadata_resource_versionResource version representing a specific version of the cronjob.
kube_cronjob_next_schedule_timeNext time the cronjob should be scheduled. The time after lastScheduleTime, or after the cron job's creation time if it's never been scheduled. Use this to determine if the job is delayed.
kube_cronjob_spec_failed_job_history_limitFailed job history limit tells the controller how many failed jobs should be preserved.
kube_cronjob_spec_starting_deadline_secondsDeadline in seconds for starting the job if it misses scheduled time for any reason.
kube_cronjob_spec_successful_job_history_limitSuccessful job history limit tells the controller how many completed jobs should be preserved.
kube_cronjob_spec_suspendSuspend flag tells the controller to suspend subsequent executions.
kube_cronjob_status_activeActive holds pointers to currently running jobs.
kube_cronjob_status_last_schedule_timeLastScheduleTime keeps information of when was the last time the job was successfully scheduled.
kube_daemonset_annotationsKubernetes annotations converted to Prometheus labels.
kube_daemonset_createdUnix creation timestamp
kube_daemonset_labelsKubernetes labels converted to Prometheus labels.
kube_daemonset_metadata_generationSequence number representing a specific generation of the desired state.
kube_daemonset_status_current_number_scheduledThe number of nodes running at least one daemon pod and are supposed to.
kube_daemonset_status_desired_number_scheduledThe number of nodes that should be running the daemon pod.
kube_daemonset_status_number_availableThe number of nodes that should be running the daemon pod and have one or more of the daemon pod running and available
kube_daemonset_status_number_misscheduledThe number of nodes running a daemon pod but are not supposed to.
kube_daemonset_status_number_readyThe number of nodes that should be running the daemon pod and have one or more of the daemon pod running and ready.
kube_daemonset_status_number_unavailableThe number of nodes that should be running the daemon pod and have none of the daemon pod running and available
kube_daemonset_status_observed_generationThe most recent generation observed by the daemon set controller.
kube_daemonset_status_updated_number_scheduledThe total number of nodes that are running updated daemon pod
kube_deployment_annotationsKubernetes annotations converted to Prometheus labels.
kube_deployment_createdUnix creation timestamp
kube_deployment_labelsKubernetes labels converted to Prometheus labels.
kube_deployment_metadata_generationSequence number representing a specific generation of the desired state.
kube_deployment_spec_pausedWhether the deployment is paused and will not be processed by the deployment controller.
kube_deployment_spec_replicasNumber of desired pods for a deployment.
kube_deployment_spec_strategy_rollingupdate_max_surgeMaximum number of replicas that can be scheduled above the desired number of replicas during a rolling update of a deployment.
kube_deployment_spec_strategy_rollingupdate_max_unavailableMaximum number of unavailable replicas during a rolling update of a deployment.
kube_deployment_status_conditionThe current status conditions of a deployment.
kube_deployment_status_observed_generationThe generation observed by the deployment controller.
kube_deployment_status_replicasThe number of replicas per deployment.
kube_deployment_status_replicas_availableThe number of available replicas per deployment.
kube_deployment_status_replicas_readyThe number of ready replicas per deployment.
kube_deployment_status_replicas_unavailableThe number of unavailable replicas per deployment.
kube_deployment_status_replicas_updatedThe number of updated replicas per deployment.
kube_endpoint_address_availableNumber of addresses available in endpoint.
kube_endpoint_address_not_readyNumber of addresses not ready in endpoint
kube_endpoint_annotationsKubernetes annotations converted to Prometheus labels.
kube_endpoint_createdUnix creation timestamp
kube_endpoint_infoInformation about endpoint.
kube_endpoint_labelsKubernetes labels converted to Prometheus labels.
kube_horizontalpodautoscaler_annotationsKubernetes annotations converted to Prometheus labels.
kube_horizontalpodautoscaler_labelsKubernetes labels converted to Prometheus labels.
kube_horizontalpodautoscaler_metadata_generationThe generation observed by the HorizontalPodAutoscaler controller.
kube_horizontalpodautoscaler_spec_max_replicasUpper limit for the number of pods that can be set by the autoscaler; cannot be smaller than MinReplicas.
kube_horizontalpodautoscaler_spec_min_replicasLower limit for the number of pods that can be set by the autoscaler, default 1.
kube_horizontalpodautoscaler_spec_target_metricThe metric specifications used by this autoscaler when calculating the desired replica count.
kube_horizontalpodautoscaler_status_conditionThe condition of this autoscaler.
kube_horizontalpodautoscaler_status_current_replicasCurrent number of replicas of pods managed by this autoscaler.
kube_horizontalpodautoscaler_status_desired_replicasDesired number of replicas of pods managed by this autoscaler.
kube_ingress_annotationsKubernetes annotations converted to Prometheus labels.
kube_ingress_createdUnix creation timestamp
kube_ingress_infoInformation about ingress.
kube_ingress_labelsKubernetes labels converted to Prometheus labels.
kube_ingress_metadata_resource_versionResource version representing a specific version of ingress.
kube_ingress_pathIngress host, paths and backend service information.
kube_ingress_tlsIngress TLS host and secret information.
kube_job_annotationsKubernetes annotations converted to Prometheus labels.
kube_job_completeThe job has completed its execution.
kube_job_createdUnix creation timestamp
kube_job_failedThe job has failed its execution.
kube_job_infoInformation about job.
kube_job_labelsKubernetes labels converted to Prometheus labels.
kube_job_ownerInformation about the Job's owner.
kube_job_spec_active_deadline_secondsThe duration in seconds relative to the startTime that the job may be active before the system tries to terminate it.
kube_job_spec_completionsThe desired number of successfully finished pods the job should be run with.
kube_job_spec_parallelismThe maximum desired number of pods the job should run at any given time.
kube_job_status_activeThe number of actively running pods.
kube_job_status_completion_timeCompletionTime represents time when the job was completed.
kube_job_status_failedThe number of pods which reached Phase Failed and the reason for failure.
kube_job_status_start_timeStartTime represents time when the job was acknowledged by the Job Manager.
kube_job_status_succeededThe number of pods which reached Phase Succeeded.
kube_limitrangeInformation about limit range.
kube_limitrange_createdUnix creation timestamp
kube_mutatingwebhookconfiguration_createdUnix creation timestamp.
kube_mutatingwebhookconfiguration_infoInformation about the MutatingWebhookConfiguration.
kube_mutatingwebhookconfiguration_metadata_resource_versionResource version representing a specific version of the MutatingWebhookConfiguration.
kube_namespace_annotationsKubernetes annotations converted to Prometheus labels.
kube_namespace_createdUnix creation timestamp
kube_namespace_labelsKubernetes labels converted to Prometheus labels.
kube_namespace_status_conditionThe condition of a namespace.
kube_namespace_status_phasekubernetes namespace status phase.
kube_networkpolicy_annotationsKubernetes annotations converted to Prometheus labels.
kube_networkpolicy_createdUnix creation timestamp of network policy
kube_networkpolicy_labelsKubernetes labels converted to Prometheus labels.
kube_networkpolicy_spec_egress_rulesNumber of egress rules on the networkpolicy
kube_networkpolicy_spec_ingress_rulesNumber of ingress rules on the networkpolicy
kube_node_annotationsKubernetes annotations converted to Prometheus labels.
kube_node_createdUnix creation timestamp
kube_node_infoInformation about a cluster node.
kube_node_labelsKubernetes labels converted to Prometheus labels.
kube_node_roleThe role of a cluster node.
kube_node_spec_taintThe taint of a cluster node.
kube_node_spec_unschedulableWhether a node can schedule new pods.
kube_node_status_allocatableThe allocatable for different resources of a node that are available for scheduling.
kube_node_status_capacityThe capacity for different resources of a node.
kube_node_status_conditionThe condition of a cluster node.
kube_persistentvolume_annotationsKubernetes annotations converted to Prometheus labels.
kube_persistentvolume_capacity_bytesPersistentvolume capacity in bytes.
kube_persistentvolume_claim_refInformation about the Persitant Volume Claim Reference.
kube_persistentvolume_infoInformation about persistentvolume.
kube_persistentvolume_labelsKubernetes labels converted to Prometheus labels.
kube_persistentvolume_status_phaseThe phase indicates if a volume is available, bound to a claim, or released by a claim.
kube_persistentvolumeclaim_access_modeThe access mode(s) specified by the persistent volume claim.
kube_persistentvolumeclaim_infoInformation about persistent volume claim.
kube_persistentvolumeclaim_labelsKubernetes labels converted to Prometheus labels.
kube_persistentvolumeclaim_resource_requests_storage_bytesThe capacity of storage requested by the persistent volume claim.
kube_persistentvolumeclaim_status_conditionInformation about status of different conditions of persistent volume claim.
kube_persistentvolumeclaim_status_phaseThe phase the persistent volume claim is currently in.
kube_pod_annotationsKubernetes annotations converted to Prometheus labels.
kube_pod_completion_timeCompletion time in unix timestamp for a pod.
kube_pod_container_infoInformation about a container in a pod.
kube_pod_container_resource_limitsThe number of requested limit resource by a container.
kube_pod_container_resource_requestsThe number of requested request resource by a container.
kube_pod_container_state_startedStart time in unix timestamp for a pod container.
kube_pod_container_status_last_terminated_reasonDescribes the last reason the container was in terminated state.
kube_pod_container_status_readyDescribes whether the containers readiness check succeeded.
kube_pod_container_status_restarts_totalThe number of container restarts per container.
kube_pod_container_status_runningDescribes whether the container is currently in running state.
kube_pod_container_status_terminatedDescribes whether the container is currently in terminated state.
kube_pod_container_status_terminated_reasonDescribes the reason the container is currently in terminated state.
kube_pod_container_status_waitingDescribes whether the container is currently in waiting state.
kube_pod_container_status_waiting_reasonDescribes the reason the container is currently in waiting state.
kube_pod_createdUnix creation timestamp
kube_pod_deletion_timestampUnix deletion timestamp
kube_pod_infoInformation about pod.
kube_pod_init_container_infoInformation about an init container in a pod.
kube_pod_init_container_resource_limitsThe number of requested limit resource by an init container.
kube_pod_init_container_resource_limits_cpu_coresThe number of CPU cores requested limit by an init container.
kube_pod_init_container_resource_limits_ephemeral_storage_bytesBytes of ephemeral-storage requested limit by an init container.
kube_pod_init_container_resource_limits_memory_bytesBytes of memory requested limit by an init container.
kube_pod_init_container_resource_limits_storage_bytesBytes of storage requested limit by an init container.
kube_pod_init_container_resource_requestsThe number of requested request resource by an init container.
kube_pod_init_container_resource_requests_cpu_coresThe number of CPU cores requested by an init container.
kube_pod_init_container_resource_requests_ephemeral_storage_bytesBytes of ephemeral-storage requested by an init container.
kube_pod_init_container_resource_requests_memory_bytesBytes of memory requested by an init container.
kube_pod_init_container_resource_requests_storage_bytesBytes of storage requested by an init container.
kube_pod_init_container_status_last_terminated_reasonDescribes the last reason the init container was in terminated state.
kube_pod_init_container_status_readyDescribes whether the init containers readiness check succeeded.
kube_pod_init_container_status_restarts_totalThe number of restarts for the init container.
kube_pod_init_container_status_runningDescribes whether the init container is currently in running state.
kube_pod_init_container_status_terminatedDescribes whether the init container is currently in terminated state.
kube_pod_init_container_status_terminated_reasonDescribes the reason the init container is currently in terminated state.
kube_pod_init_container_status_waitingDescribes whether the init container is currently in waiting state.
kube_pod_init_container_status_waiting_reasonDescribes the reason the init container is currently in waiting state.
kube_pod_labelsKubernetes labels converted to Prometheus labels.
kube_pod_overhead_cpu_coresThe pod overhead in regards to cpu cores associated with running a pod.
kube_pod_overhead_memory_bytesThe pod overhead in regards to memory associated with running a pod.
kube_pod_ownerInformation about the Pod's owner.
kube_pod_restart_policyDescribes the restart policy in use by this pod.
kube_pod_runtimeclass_name_infoThe runtimeclass associated with the pod.
kube_pod_spec_volumes_persistentvolumeclaims_infoInformation about persistentvolumeclaim volumes in a pod.
kube_pod_spec_volumes_persistentvolumeclaims_readonlyDescribes whether a persistentvolumeclaim is mounted read only.
kube_pod_start_timeStart time in unix timestamp for a pod.
kube_pod_status_phaseThe pods current phase.
kube_pod_status_readyDescribes whether the pod is ready to serve requests.
kube_pod_status_reasonThe pod status reasons
kube_pod_status_scheduledDescribes the status of the scheduling process for the pod.
kube_pod_status_scheduled_timeUnix timestamp when pod moved into scheduled status
kube_pod_status_unschedulableDescribes the unschedulable status for the pod.
kube_poddisruptionbudget_createdUnix creation timestamp
kube_poddisruptionbudget_status_current_healthyCurrent number of healthy pods
kube_poddisruptionbudget_status_desired_healthyMinimum desired number of healthy pods
kube_poddisruptionbudget_status_expected_podsTotal number of pods counted by this disruption budget
kube_poddisruptionbudget_status_observed_generationMost recent generation observed when updating this PDB status
kube_poddisruptionbudget_status_pod_disruptions_allowedNumber of pod disruptions that are currently allowed
kube_replicaset_annotationsKubernetes annotations converted to Prometheus labels.
kube_replicaset_createdUnix creation timestamp
kube_replicaset_labelsKubernetes labels converted to Prometheus labels.
kube_replicaset_metadata_generationSequence number representing a specific generation of the desired state.
kube_replicaset_ownerInformation about the ReplicaSet's owner.
kube_replicaset_spec_replicasNumber of desired pods for a ReplicaSet.
kube_replicaset_status_fully_labeled_replicasThe number of fully labeled replicas per ReplicaSet.
kube_replicaset_status_observed_generationThe generation observed by the ReplicaSet controller.
kube_replicaset_status_ready_replicasThe number of ready replicas per ReplicaSet.
kube_replicaset_status_replicasThe number of replicas per ReplicaSet.
kube_replicationcontroller_createdUnix creation timestamp
kube_replicationcontroller_metadata_generationSequence number representing a specific generation of the desired state.
kube_replicationcontroller_ownerInformation about the ReplicationController's owner.
kube_replicationcontroller_spec_replicasNumber of desired pods for a ReplicationController.
kube_replicationcontroller_status_available_replicasThe number of available replicas per ReplicationController.
kube_replicationcontroller_status_fully_labeled_replicasThe number of fully labeled replicas per ReplicationController.
kube_replicationcontroller_status_observed_generationThe generation observed by the ReplicationController controller.
kube_replicationcontroller_status_ready_replicasThe number of ready replicas per ReplicationController.
kube_replicationcontroller_status_replicasThe number of replicas per ReplicationController.
kube_resourcequotaInformation about resource quota.
kube_resourcequota_createdUnix creation timestamp
kube_secret_annotationsKubernetes annotations converted to Prometheus labels.
kube_secret_createdUnix creation timestamp
kube_secret_infoInformation about secret.
kube_secret_labelsKubernetes labels converted to Prometheus labels.
kube_secret_metadata_resource_versionResource version representing a specific version of secret.
kube_secret_typeType about secret.
kube_service_annotationsKubernetes annotations converted to Prometheus labels.
kube_service_createdUnix creation timestamp
kube_service_infoInformation about service.
kube_service_labelsKubernetes labels converted to Prometheus labels.
kube_service_spec_external_ipService external ips. One series for each ip
kube_service_spec_typeType about service.
kube_service_status_load_balancer_ingressService load balancer ingress status
kube_statefulset_annotationsKubernetes annotations converted to Prometheus labels.
kube_statefulset_createdUnix creation timestamp
kube_statefulset_labelsKubernetes labels converted to Prometheus labels.
kube_statefulset_metadata_generationSequence number representing a specific generation of the desired state for the StatefulSet.
kube_statefulset_replicasNumber of desired pods for a StatefulSet.
kube_statefulset_status_current_revisionIndicates the version of the StatefulSet used to generate Pods in the sequence [0,currentReplicas).
kube_statefulset_status_observed_generationThe generation observed by the StatefulSet controller.
kube_statefulset_status_replicasThe number of replicas per StatefulSet.
kube_statefulset_status_replicas_availableThe number of available replicas per StatefulSet.
kube_statefulset_status_replicas_currentThe number of current replicas per StatefulSet.
kube_statefulset_status_replicas_readyThe number of ready replicas per StatefulSet.
kube_statefulset_status_replicas_updatedThe number of updated replicas per StatefulSet.
kube_statefulset_status_update_revisionIndicates the version of the StatefulSet used to generate Pods in the sequence [replicas-updatedReplicas,replicas)
kube_storageclass_annotationsKubernetes annotations converted to Prometheus labels.
kube_storageclass_createdUnix creation timestamp
kube_storageclass_infoInformation about storageclass.
kube_storageclass_labelsKubernetes labels converted to Prometheus labels.
kube_validatingwebhookconfiguration_createdUnix creation timestamp.
kube_validatingwebhookconfiguration_infoInformation about the ValidatingWebhookConfiguration.
kube_validatingwebhookconfiguration_metadata_resource_versionResource version representing a specific version of the ValidatingWebhookConfiguration.
kube_volumeattachment_createdUnix creation timestamp
kube_volumeattachment_infoInformation about volumeattachment.
kube_volumeattachment_labelsKubernetes labels converted to Prometheus labels.
kube_volumeattachment_spec_source_persistentvolumePersistentVolume source reference.
kube_volumeattachment_status_attachedInformation about volumeattachment.
kube_volumeattachment_status_attachment_metadatavolumeattachment metadata.
log_messagesTotal number of log messages.
logback_events_totalNumber of error level events that made it to the logs
logql_query_duration_secondsLogQL query timings
loki_boltdb_shipper_compact_tables_operationTotal number of tables compaction done by status
loki_boltdb_shipper_compact_tables_operation_duration_secondsTime (in seconds) spent in compacting all the tables
loki_boltdb_shipper_compact_tables_operation_last_successful_run_timestamp_secondsUnix timestamp of the last successful compaction run
loki_boltdb_shipper_initial_tables_download_duration_secondsTime (in seconds) spent in downloading of files per table, initially i.e for the first time
loki_boltdb_shipper_initial_tables_download_size_bytesSize of files (in bytes) downloaded per table, initially i.e for the first time
loki_boltdb_shipper_open_existing_file_failuresTotal number of failures in opening of existing files while loading active index tables during startup
loki_boltdb_shipper_request_duration_secondsTime (in seconds) spent serving requests when using boltdb shipper
loki_boltdb_shipper_tables_sync_operationTotal number of tables sync operations done by status
loki_boltdb_shipper_tables_upload_operationTotal number of upload operations done by status
loki_build_infoA metric with a constant '1' value labeled by version, revision, branch, and goversion from which loki was built.
loki_distributor_bytes_receivedThe total number of uncompressed bytes received per tenant
loki_distributor_ingester_appendsThe total number of batch appends sent to ingesters.
loki_distributor_lines_receivedThe total number of lines received per tenant
loki_distributor_replication_factorThe configured replication factor.
loki_index_chunk_refsNumber of chunks refs downloaded, partitioned by whether they intersect the query bounds.
loki_inflight_requestsCurrent number of inflight requests.
loki_ingester_autoforget_unhealthy_ingestersTotal number of ingesters automatically forgotten
loki_ingester_blocks_per_chunkThe number of blocks in a chunk.
loki_ingester_checkpoint_creationsTotal number of checkpoint creations attempted.
loki_ingester_checkpoint_creations_failedTotal number of checkpoint creations that failed.
loki_ingester_checkpoint_deletionsTotal number of checkpoint deletions attempted.
loki_ingester_checkpoint_deletions_failedTotal number of checkpoint deletions that failed.
loki_ingester_checkpoint_duration_secondsTime taken to create a checkpoint.
loki_ingester_checkpoint_logged_bytesTotal number of bytes written to disk for checkpointing.
loki_ingester_chunk_age_secondsDistribution of chunk ages (when stored).
loki_ingester_chunk_bounds_hoursDistribution of chunk end-start durations.
loki_ingester_chunk_compression_ratioCompression ratio of chunks (when stored).
loki_ingester_chunk_encode_time_secondsDistribution of chunk encode times.
loki_ingester_chunk_entriesDistribution of stored lines per chunk (when stored).
loki_ingester_chunk_size_bytesDistribution of stored chunk sizes (when stored).
loki_ingester_chunk_stored_bytesTotal bytes stored in chunks per tenant.
loki_ingester_chunk_utilizationDistribution of stored chunk utilization (when stored).
loki_ingester_chunks_createdThe total number of chunks created in the ingester.
loki_ingester_chunks_flushedTotal flushed chunks per reason.
loki_ingester_chunks_storedTotal stored chunks per tenant.
loki_ingester_client_request_duration_secondsTime spent doing Ingester requests.
loki_ingester_memory_chunksThe total number of chunks in memory.
loki_ingester_memory_streamsThe total number of streams in memory per tenant.
loki_ingester_received_chunksThe total number of chunks received by this ingester whilst joining.
loki_ingester_samples_per_chunkThe number of samples in a chunk.
loki_ingester_sent_chunksThe total number of chunks sent by this ingester whilst leaving.
loki_ingester_streams_createdThe total number of streams created per tenant.
loki_ingester_streams_removedThe total number of streams removed per tenant.
loki_ingester_wal_bytes_in_useTotal number of bytes in use by the WAL recovery process.
loki_ingester_wal_disk_full_failuresTotal number of wal write failures due to full disk.
loki_ingester_wal_duplicate_entriesEntries discarded during WAL replay due to existing in checkpoints.
loki_ingester_wal_logged_bytesTotal number of bytes written to disk for WAL records.
loki_ingester_wal_records_loggedTotal number of WAL records logged.
loki_ingester_wal_recovered_bytesTotal number of bytes recovered from the WAL.
loki_ingester_wal_recovered_chunksTotal number of chunks recovered from the WAL checkpoints.
loki_ingester_wal_recovered_entriesTotal number of entries recovered from the WAL.
loki_ingester_wal_recovered_streamsTotal number of streams recovered from the WAL.
loki_ingester_wal_replay_duration_secondsTime taken to replay the checkpoint and the WAL.
loki_ingester_wal_replay_flushingWhether the wal replay is in a flushing phase due to backpressure
loki_logql_querystats_bytes_processed_per_secondsDistribution of bytes processed per second for LogQL queries.
loki_logql_querystats_chunk_download_latency_secondsDistribution of chunk downloads latency for LogQL queries.
loki_logql_querystats_downloaded_chunkTotal count of chunks downloaded found while executing LogQL queries.
loki_logql_querystats_duplicatesTotal count of duplicates found while executing LogQL queries.
loki_logql_querystats_ingester_sent_linesTotal count of lines sent from ingesters while executing LogQL queries.
loki_logql_querystats_latency_secondsDistribution of latency for LogQL queries.
loki_panicThe total number of panic triggered
loki_request_duration_secondsTime (in seconds) spent serving HTTP requests.
loki_request_message_bytesSize (in bytes) of messages received in the request.
loki_response_message_bytesSize (in bytes) of messages sent in response.
loki_store_chunks_downloadedNumber of chunks referenced or downloaded, partitioned by if they satisfy matchers.
loki_store_chunks_per_batchThe chunk batch size, partitioned by if they satisfy matchers.
loki_store_seriesNumber of series referenced by a query, partitioned by whether they satisfy matchers.
loki_tcp_connectionsCurrent number of accepted TCP connections.
meshdb_subscription_items_total
meshdb_subscription_progress_timestamp_seconds
meshdb_subscription_restarts_total
meshdb_subscription_retry_total
meshfed_activeUsersmeshfed_activeUsers
meshfed_allUsersmeshfed_allUsers
meshfed_customerCountmeshfed_customerCount
meshfed_inactiveUsersmeshfed_inactiveUsers
meshfed_platformmeshfed
meshfed_projectCountmeshfed_projectCount
meshfed_project_tenantsThe number of tenants in one project
meshfed_service_bindingThe number of service bindings in the meshMarketplace
meshfed_service_instanceThe number of service instances in the meshMarketplace
meshfed_tenant_countmeshfed_tenant
meshfedapi_db_subscription_items_total
meshfedapi_db_subscription_progress_timestamp_seconds
meshfedapi_db_subscription_restarts_total
meshfedapi_db_subscription_retry_total
mysql_exporter_collector_duration_secondsCollector time duration.
mysql_exporter_last_scrape_errorWhether the last scrape of metrics from MySQL resulted in an error (1 for error, 0 for success).
mysql_exporter_scrapes_totalTotal number of times MySQL was scraped for metrics.
mysql_galera_variables_infoPXC/Galera variables information.
mysql_global_status_aborted_clientsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aborted_connectsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aborted_connects_preauthGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_access_denied_errorsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_column_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_database_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_function_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_package_body_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_package_spec_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_procedure_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_proxy_usersGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_role_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_rolesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_table_grantsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_acl_usersGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_blocks_not_flushedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_blocks_unusedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_blocks_usedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_read_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_write_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_pagecache_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_aria_transaction_log_syncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_bytes_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_cache_disk_useGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_cache_useGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_commitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_group_commit_trigger_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_group_commit_trigger_lock_waitGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_group_commit_trigger_timeoutGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_group_commitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_snapshot_positionGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_stmt_cache_disk_useGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_binlog_stmt_cache_useGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_buffer_pool_dirty_pagesInnodb buffer pool dirty pages.
mysql_global_status_buffer_pool_page_changes_totalInnodb buffer pool page state changes.
mysql_global_status_buffer_pool_pagesInnodb buffer pool pages by state.
mysql_global_status_busy_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_bytes_receivedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_bytes_sentGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_column_compressionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_column_decompressionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_commands_totalTotal number of executed MySQL commands.
mysql_global_status_compressionGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_connection_errors_totalTotal number of MySQL connection errors.
mysql_global_status_connectionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_cpu_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_created_tmp_disk_tablesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_created_tmp_filesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_created_tmp_tablesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_delayed_errorsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_delayed_insert_threadsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_delayed_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_delete_scanGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_empty_queriesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_executed_eventsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_executed_triggersGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_application_time_periodsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_check_constraintGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_custom_aggregate_functionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_delay_key_writeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_dynamic_columnsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_fulltextGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_gisGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_insert_returningGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_invisible_columnsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_jsonGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_localeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_subqueryGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_system_versioningGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_timezoneGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_triggerGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_window_functionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_feature_xmlGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_handlers_totalTotal number of executed MySQL handlers.
mysql_global_status_innodb_adaptive_hash_hash_searchesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_adaptive_hash_non_hash_searchesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_available_undo_logsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_background_log_syncGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_bytes_dataGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_bytes_dirtyGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_load_incompleteGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_read_aheadGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_read_ahead_evictedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_read_ahead_rndGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_read_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_wait_freeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_buffer_pool_write_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_checkpoint_ageGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_checkpoint_max_ageGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_fsyncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_pending_fsyncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_pending_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_pending_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_readGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_data_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_dblwr_pages_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_dblwr_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_deadlocksGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_defragment_compression_failuresGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_defragment_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_defragment_failuresGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_key_rotation_list_lengthGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_merge_blocks_decryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_merge_blocks_encryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_rowlog_blocks_decryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_rowlog_blocks_encryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_temp_blocks_decryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_n_temp_blocks_encryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_num_key_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_rotation_estimated_iopsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_rotation_pages_flushedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_rotation_pages_modifiedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_rotation_pages_read_from_cacheGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_encryption_rotation_pages_read_from_diskGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_bzip2Generic metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_lz4Generic metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_lzmaGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_lzoGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_punch_holeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_have_snappyGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_history_list_lengthGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_discarded_delete_marksGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_discarded_deletesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_discarded_insertsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_free_listGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_merged_delete_marksGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_merged_deletesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_merged_insertsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_mergesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_segment_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_ibuf_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_instant_alter_columnGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_log_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_log_write_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_log_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_lsn_currentGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_lsn_flushedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_lsn_last_checkpointGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_master_thread_active_loopsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_master_thread_idle_loopsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_max_trx_idGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_mem_adaptive_hashGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_mem_dictionaryGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_index_pages_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_non_index_pages_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_open_filesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_page_compressed_trim_opGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_pages_decryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_pages_encryptedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_pages_page_compressedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_pages_page_compression_errorGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_num_pages_page_decompressedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_onlineddl_pct_progressGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_onlineddl_rowlog_pct_usedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_onlineddl_rowlog_rowsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_os_log_fsyncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_os_log_pending_fsyncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_os_log_pending_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_os_log_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_page_compression_savedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_page_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_pages_createdGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_pages_readGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_pages_writtenGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_lock_current_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_lock_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_lock_time_avgGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_lock_time_maxGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_lock_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_row_ops_totalTotal number of MySQL InnoDB row operations.
mysql_global_status_innodb_secondary_index_triggered_cluster_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_secondary_index_triggered_cluster_reads_avoidedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_system_rows_deletedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_system_rows_insertedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_system_rows_readGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_system_rows_updatedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_truncated_status_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_innodb_undo_truncationsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_blocks_not_flushedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_blocks_unusedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_blocks_usedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_blocks_warmGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_read_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_readsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_write_requestsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_key_writesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_last_query_costGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_master_gtid_wait_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_master_gtid_wait_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_master_gtid_wait_timeoutsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_max_statement_time_exceededGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_max_used_connectionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_memory_usedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_memory_used_initialGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_not_flushed_delayed_rowsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_open_filesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_open_streamsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_open_table_definitionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_open_tablesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_opened_filesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_opened_plugin_librariesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_opened_table_definitionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_opened_tablesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_opened_viewsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_performance_schema_lost_totalTotal number of MySQL instrumentations that could not be loaded or created due to memory constraints.
mysql_global_status_prepared_stmt_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_free_blocksGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_free_memoryGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_hitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_insertsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_lowmem_prunesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_not_cachedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_queries_in_cacheGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_qcache_total_blocksGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_queriesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_questionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rows_readGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rows_sentGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rows_tmp_readGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_clientsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_get_ackGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_net_avg_wait_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_net_wait_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_net_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_no_timesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_no_txGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_request_ackGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_statusGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_timefunc_failuresGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_tx_avg_wait_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_tx_wait_timeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_tx_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_wait_pos_backtraverseGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_wait_sessionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_master_yes_txGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_slave_send_ackGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_semi_sync_slave_statusGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_rpl_transactions_multi_engineGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_select_full_joinGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_select_full_range_joinGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_select_rangeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_select_range_checkGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_select_scanGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_connectionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_heartbeat_periodGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_open_temp_tablesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_received_heartbeatsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_retried_transactionsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_runningGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slave_skipped_errorsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slaves_connectedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slaves_runningGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slow_launch_threadsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_slow_queriesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_sort_merge_passesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_sort_priority_queue_sortsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_sort_rangeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_sort_rowsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_sort_scanGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_accept_renegotiatesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_acceptsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_callback_cache_hitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_client_connectsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_connect_renegotiatesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_ctx_verify_depthGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_ctx_verify_modeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_default_timeoutGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_finished_acceptsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_finished_connectsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_session_cache_hitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_session_cache_missesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_session_cache_overflowsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_session_cache_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_session_cache_timeoutsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_sessions_reusedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_used_session_cache_entriesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_verify_depthGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_ssl_verify_modeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_subquery_cache_hitGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_subquery_cache_missGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_syncsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_locks_immediateGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_locks_waitedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_open_cache_active_instancesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_open_cache_hitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_open_cache_missesGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_table_open_cache_overflowsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_tc_log_max_pages_usedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_tc_log_page_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_tc_log_page_waitsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threadpool_idle_threadsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threadpool_threadsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threads_cachedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threads_connectedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threads_createdGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_threads_runningGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_transactions_gtid_foreign_engineGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_transactions_multi_engineGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_update_scanGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_uptimeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_uptime_since_flush_statusGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrepGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_applier_thread_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_cluster_conf_idGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_cluster_sizeGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_cluster_statusGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_connectedGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_local_bf_abortsGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_local_indexGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_readyGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_rollbacker_thread_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_status_wsrep_thread_countGeneric metric from SHOW GLOBAL STATUS.
mysql_global_variables_analyze_sample_percentageGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_checkpoint_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_checkpoint_log_activityGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_encrypt_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_force_start_after_recovery_failuresGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_group_commit_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_log_file_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_max_sort_file_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_page_checksumGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_pagecache_age_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_pagecache_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_pagecache_division_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_pagecache_file_hash_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_repair_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_sort_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_aria_used_for_temp_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_auto_increment_incrementGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_auto_increment_offsetGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_autocommitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_automatic_sp_privilegesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_back_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_big_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_annotate_row_eventsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_commit_wait_countGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_commit_wait_usecGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_direct_non_transactional_updatesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_file_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_optimize_thread_schedulingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_binlog_stmt_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_bulk_insert_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_check_constraint_checksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_column_compression_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_column_compression_zlib_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_column_compression_zlib_wrapGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_connect_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_core_fileGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_deadlock_search_depth_longGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_deadlock_search_depth_shortGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_deadlock_timeout_longGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_deadlock_timeout_shortGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_debug_no_thread_alarmGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_default_password_lifetimeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_default_week_formatGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_delay_key_writeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_delayed_insert_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_delayed_insert_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_delayed_queue_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_disconnect_on_expired_passwordGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_div_precision_incrementGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_encrypt_binlogGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_encrypt_tmp_disk_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_encrypt_tmp_filesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_eq_range_index_dive_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_event_schedulerGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_expensive_subquery_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_expire_logs_daysGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_explicit_defaults_for_timestampGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_extra_max_connectionsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_extra_portGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_flushGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_flush_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_foreign_key_checksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_ft_max_word_lenGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_ft_min_word_lenGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_ft_query_expansion_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_general_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_group_concat_max_lenGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_gtid_cleanup_batch_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_gtid_domain_idGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_gtid_ignore_duplicatesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_gtid_strict_modeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_compressGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_cryptGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_dynamic_loadingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_geometryGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_opensslGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_profilingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_query_cacheGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_rtree_keysGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_sslGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_have_symlinkGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_histogram_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_host_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_idle_readonly_transaction_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_idle_transaction_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_idle_write_transaction_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_ignore_builtin_innodbGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_in_predicate_conversion_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_adaptive_flushingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_adaptive_flushing_lwmGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_adaptive_hash_indexGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_adaptive_hash_index_partsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_adaptive_max_sleep_delayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_autoextend_incrementGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_autoinc_lock_modeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_background_scrub_data_check_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_background_scrub_data_compressedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_background_scrub_data_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_background_scrub_data_uncompressedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buf_dump_status_frequencyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_chunk_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_dump_at_shutdownGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_dump_nowGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_dump_pctGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_load_abortGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_load_at_startupGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_load_nowGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_buffer_pool_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_change_buffer_max_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_cmp_per_index_enabledGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_commit_concurrencyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_compression_defaultGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_compression_failure_threshold_pctGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_compression_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_compression_pad_pct_maxGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_concurrency_ticketsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_deadlock_detectGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_default_encryption_key_idGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragmentGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragment_fill_factorGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragment_fill_factor_n_recsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragment_frequencyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragment_n_pagesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_defragment_stats_accuracyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_disable_sort_file_cacheGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_disallow_writesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_doublewriteGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encrypt_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encrypt_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encrypt_temporary_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encryption_rotate_key_ageGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encryption_rotation_iopsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_encryption_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_fast_shutdownGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_fatal_semaphore_wait_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_file_per_tableGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_fill_factorGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_flush_log_at_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_flush_log_at_trx_commitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_flush_neighborsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_flush_syncGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_flushing_avg_loopsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_force_load_corruptedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_force_primary_keyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_force_recoveryGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_enable_diag_printGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_enable_stopwordGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_max_token_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_min_token_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_num_word_optimizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_result_cache_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_sort_pll_degreeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_ft_total_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_immediate_scrub_data_uncompressedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_io_capacityGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_io_capacity_maxGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_lock_wait_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_checksumsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_compressed_pagesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_file_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_files_in_groupGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_optimize_ddlGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_log_write_ahead_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_lru_flush_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_lru_scan_depthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_dirty_pages_pctGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_dirty_pages_pct_lwmGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_purge_lagGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_purge_lag_delayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_purge_lag_waitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_max_undo_log_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_old_blocks_pctGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_old_blocks_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_online_alter_log_max_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_open_filesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_optimize_fulltext_onlyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_page_cleanersGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_page_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_prefix_index_cluster_optimizationGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_print_all_deadlocksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_purge_batch_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_purge_rseg_truncate_frequencyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_purge_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_random_read_aheadGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_read_ahead_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_read_io_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_read_onlyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_replication_delayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_rollback_on_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_scrub_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_scrub_log_speedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_sort_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_spin_wait_delayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_auto_recalcGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_include_delete_markedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_modified_counterGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_on_metadataGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_persistentGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_persistent_sample_pagesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_traditionalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_stats_transient_sample_pagesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_status_outputGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_status_output_locksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_strict_modeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_sync_array_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_sync_spin_loopsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_table_locksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_thread_concurrencyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_thread_sleep_delayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_undo_log_truncateGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_undo_logsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_undo_tablespacesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_use_atomic_writesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_use_native_aioGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_innodb_write_io_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_interactive_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_join_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_join_buffer_space_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_join_cache_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_keep_files_on_createGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_cache_age_thresholdGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_cache_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_cache_division_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_cache_file_hash_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_key_cache_segmentsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_large_files_supportGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_large_page_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_large_pagesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_local_infileGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_lock_wait_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_locked_in_memoryGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_binGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_bin_compressGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_bin_compress_min_lenGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_bin_trust_function_creatorsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_queries_not_using_indexesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_slave_updatesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_slow_admin_statementsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_slow_rate_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_slow_slave_statementsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_tc_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_log_warningsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_long_query_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_low_priority_updatesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_lower_case_file_systemGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_lower_case_table_namesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_master_verify_checksumGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_allowed_packetGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_binlog_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_binlog_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_binlog_stmt_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_connect_errorsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_connectionsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_delayed_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_digest_lengthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_error_countGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_heap_table_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_insert_delayed_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_join_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_length_for_sort_dataGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_password_errorsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_prepared_stmt_countGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_recursive_iterationsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_relay_log_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_rowid_filter_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_seeks_for_keyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_session_mem_usedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_sort_lengthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_sp_recursion_depthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_statement_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_tmp_tablesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_user_connectionsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_max_write_lock_countGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_metadata_locks_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_metadata_locks_hash_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_min_examined_row_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_mrr_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_data_pointer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_max_sort_file_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_mmap_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_repair_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_sort_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_myisam_use_mmapGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_mysql56_temporal_formatGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_net_buffer_lengthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_net_read_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_net_retry_countGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_net_write_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_oldGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_old_passwordsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_open_files_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_max_sel_arg_weightGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_prune_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_search_depthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_selectivity_sampling_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_trace_max_mem_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_optimizer_use_condition_selectivityGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schemaGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_accounts_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_digests_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_stages_history_long_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_stages_history_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_statements_history_long_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_statements_history_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_transactions_history_long_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_transactions_history_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_waits_history_long_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_events_waits_history_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_hosts_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_cond_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_cond_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_digest_lengthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_file_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_file_handlesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_file_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_index_statGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_memory_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_metadata_locksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_mutex_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_mutex_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_prepared_statements_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_program_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_rwlock_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_rwlock_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_socket_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_socket_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_sql_text_lengthGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_stage_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_statement_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_statement_stackGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_table_handlesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_table_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_table_lock_statGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_thread_classesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_max_thread_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_session_connect_attrs_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_setup_actors_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_setup_objects_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_performance_schema_users_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_portGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_preload_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_profilingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_profiling_history_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_progress_report_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_protocol_versionGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_alloc_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_min_res_unitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_strip_commentsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_typeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_cache_wlock_invalidateGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_query_prealloc_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_range_alloc_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_read_binlog_speed_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_read_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_read_onlyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_read_rnd_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_relay_log_purgeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_relay_log_recoveryGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_relay_log_space_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_replicate_annotate_row_eventsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_report_portGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_require_secure_transportGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rowid_merge_buff_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_master_enabledGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_master_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_master_trace_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_master_wait_no_slaveGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_slave_delay_masterGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_slave_enabledGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_slave_kill_conn_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_rpl_semi_sync_slave_trace_levelGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_secure_authGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_secure_timestampGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_server_idGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_session_track_schemaGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_session_track_state_changeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_session_track_transaction_infoGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_skip_external_lockingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_skip_name_resolveGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_skip_networkingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_skip_show_databaseGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_compressed_protocolGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_domain_parallel_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_max_allowed_packetGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_net_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_parallel_max_queuedGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_parallel_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_parallel_workersGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_run_triggers_for_rbrGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_skip_errorsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_sql_verify_checksumGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_transaction_retriesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slave_transaction_retry_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slow_launch_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_slow_query_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sort_buffer_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_auto_is_nullGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_big_selectsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_buffer_resultGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_if_existsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_log_binGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_log_offGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_notesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_quote_show_createGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_safe_updatesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_select_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_slave_skip_counterGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sql_warningsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_standard_compliant_cteGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_stored_program_cacheGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_strict_password_validationGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sync_binlogGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sync_frmGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sync_master_infoGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sync_relay_logGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_sync_relay_log_infoGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_table_definition_cacheGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_table_open_cacheGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_table_open_cache_instancesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tcp_keepalive_intervalGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tcp_keepalive_probesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tcp_keepalive_timeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tcp_nodelayGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_cache_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_dedicated_listenerGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_exact_statsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_idle_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_max_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_oversubscribeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_prio_kickup_timerGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_pool_stall_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_thread_stackGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tmp_disk_table_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tmp_memory_table_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tmp_table_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_transaction_alloc_block_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_transaction_prealloc_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_tx_read_onlyGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_unique_checksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_updatable_views_with_limitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_userstatGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wait_timeoutGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_auto_increment_controlGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_causal_readsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_certify_nonpkGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_convert_lock_to_trxGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_desyncGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_dirty_readsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_drupal_282555_workaroundGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_gtid_domain_idGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_gtid_modeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_ignore_apply_errorsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_load_data_splittingGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_log_conflictsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_max_ws_rowsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_max_ws_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_mysql_replication_bundleGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_onGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_recoverGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_replicate_myisamGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_restart_slaveGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_retry_autocommitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_slave_fk_checksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_slave_threadsGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_slave_uk_checksGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_sst_donor_rejects_queriesGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_strict_ddlGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_sync_waitGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_global_variables_wsrep_trx_fragment_sizeGeneric gauge metric from SHOW GLOBAL VARIABLES.
mysql_info_schema_innodb_cmp_compress_ops_ok_totalNumber of times a B-tree page of the size PAGE_SIZE has been successfully compressed.
mysql_info_schema_innodb_cmp_compress_ops_totalNumber of times a B-tree page of the size PAGE_SIZE has been compressed.
mysql_info_schema_innodb_cmp_compress_time_seconds_totalTotal time in seconds spent in attempts to compress B-tree pages.
mysql_info_schema_innodb_cmp_uncompress_ops_totalNumber of times a B-tree page of the size PAGE_SIZE has been uncompressed.
mysql_info_schema_innodb_cmp_uncompress_time_seconds_totalTotal time in seconds spent in uncompressing B-tree pages.
mysql_info_schema_innodb_cmpmem_pages_free_totalNumber of blocks of the size PAGE_SIZE that are currently available for allocation.
mysql_info_schema_innodb_cmpmem_pages_used_totalNumber of blocks of the size PAGE_SIZE that are currently in use.
mysql_info_schema_innodb_cmpmem_relocation_ops_totalNumber of times a block of the size PAGE_SIZE has been relocated.
mysql_info_schema_innodb_cmpmem_relocation_time_seconds_totalTotal time in seconds spent in relocating blocks.
mysql_slave_status_connect_retryGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_exec_master_log_posGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_executed_log_entriesGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_last_errnoGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_last_io_errnoGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_last_sql_errnoGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_master_portGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_master_server_idGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_master_ssl_allowedGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_master_ssl_verify_server_certGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_max_relay_log_sizeGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_read_master_log_posGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_relay_log_posGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_relay_log_spaceGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_retried_transactionsGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_seconds_behind_masterGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_skip_counterGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_ddl_groupsGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_heartbeat_periodGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_io_runningGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_non_transactional_groupsGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_received_heartbeatsGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_sql_runningGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_slave_transactional_groupsGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_sql_delayGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_until_log_posGeneric metric from SHOW SLAVE STATUS.
mysql_slave_status_using_gtidGeneric metric from SHOW SLAVE STATUS.
mysql_upWhether the MySQL server is up.
mysql_version_infoMySQL version and distribution.
mysqld_exporter_build_infoA metric with a constant '1' value labeled by version, revision, branch, and goversion from which mysqld_exporter was built.
net_conntrack_dialer_conn_attempted_totalTotal number of connections attempted by the given dialer a given name.
net_conntrack_dialer_conn_closed_totalTotal number of connections closed which originated from the dialer of a given name.
net_conntrack_dialer_conn_established_totalTotal number of connections successfully established by the given dialer a given name.
net_conntrack_dialer_conn_failed_totalTotal number of connections failed to dial by the dialer a given name.
net_conntrack_listener_conn_accepted_totalTotal number of connections opened to the listener of a given name.
net_conntrack_listener_conn_closed_totalTotal number of connections closed that were made to the listener of a given name.
os_fd_limitThe file descriptor limit.
os_fd_usedThe number of used file descriptors.
probe_dns_lookup_time_secondsReturns the time taken for probe dns lookup in seconds
probe_duration_secondsReturns how long the probe took to complete in seconds
probe_failed_due_to_regexIndicates if probe failed due to regex
probe_http_content_lengthLength of http content response
probe_http_duration_secondsDuration of http request by phase, summed over all redirects
probe_http_redirectsThe number of redirects
probe_http_sslIndicates if SSL was used for the final redirect
probe_http_status_codeResponse HTTP status code
probe_http_uncompressed_body_lengthLength of uncompressed response body
probe_http_versionReturns the version of HTTP of the probe response
probe_ip_addr_hashSpecifies the hash of IP address. It's useful to detect if the IP address changes.
probe_ip_protocolSpecifies whether probe ip protocol is IP4 or IP6
probe_ssl_earliest_cert_expiryReturns earliest SSL cert expiry in unixtime
probe_ssl_last_chain_expiry_timestamp_secondsReturns last SSL chain expiry in timestamp seconds
probe_ssl_last_chain_infoContains SSL leaf certificate information
probe_successDisplays whether or not the probe was a success
probe_tls_version_infoContains the TLS version used
process_cpu_secondsTotal user and system CPU time spent in seconds.
process_cpu_seconds_totalTotal user and system CPU time spent in seconds.
process_cpu_usageThe "recent cpu usage" for the Java Virtual Machine process
process_files_max_filesThe maximum file descriptor count
process_files_open_filesThe open file descriptor count
process_max_fdsMaximum number of open file descriptors.
process_open_fdsNumber of open file descriptors.
process_resident_memory_bytesResident memory size in bytes.
process_start_time_secondsStart time of the process since unix epoch.
process_uptime_secondsThe uptime of the Java virtual machine
process_virtual_memory_bytesVirtual memory size in bytes.
process_virtual_memory_max_bytesMaximum amount of virtual memory available in bytes.
prometheus_api_remote_read_queriesThe current number of remote read queries being executed or waiting.
prometheus_build_infoA metric with a constant '1' value labeled by version, revision, branch, and goversion from which prometheus was built.
prometheus_config_last_reload_success_timestamp_secondsTimestamp of the last successful configuration reload.
prometheus_config_last_reload_successfulWhether the last configuration reload attempt was successful.
prometheus_engine_queriesThe current number of queries being executed or waiting.
prometheus_engine_queries_concurrent_maxThe max number of concurrent queries.
prometheus_engine_query_duration_secondsQuery timings
prometheus_engine_query_log_enabledState of the query log.
prometheus_engine_query_log_failures_totalThe number of query log failures.
prometheus_http_request_duration_secondsHistogram of latencies for HTTP requests.
prometheus_http_requests_totalCounter of HTTP requests.
prometheus_http_response_size_bytesHistogram of response size for HTTP requests.
prometheus_local_storage_memory_chunkdescsThe current number of chunk descriptors in memory.
prometheus_notifications_alertmanagers_discoveredThe number of alertmanagers discovered and active.
prometheus_notifications_dropped_totalTotal number of alerts dropped due to errors when sending to Alertmanager.
prometheus_notifications_queue_capacityThe capacity of the alert notifications queue.
prometheus_notifications_queue_lengthThe number of alert notifications in the queue.
prometheus_remote_storage_enqueue_retries_totalTotal number of times enqueue has failed because a shards queue was full.
prometheus_remote_storage_exemplars_inExemplars in to remote storage, compare to exemplars out for queue managers.
prometheus_remote_storage_highest_timestamp_in_secondsHighest timestamp that has come into the remote storage via the Appender interface, in seconds since epoch.
prometheus_remote_storage_max_samples_per_sendThe maximum number of samples to be sent, in a single request, to the remote storage.
prometheus_remote_storage_metadata_bytes_totalThe total number of bytes of metadata sent by the queue after compression.
prometheus_remote_storage_metadata_failed_totalTotal number of metadata entries which failed on send to remote storage, non-recoverable errors.
prometheus_remote_storage_metadata_retried_totalTotal number of metadata entries which failed on send to remote storage but were retried because the send error was recoverable.
prometheus_remote_storage_metadata_totalTotal number of metadata entries sent to remote storage.
prometheus_remote_storage_queue_highest_sent_timestamp_secondsTimestamp from a WAL sample, the highest timestamp successfully sent by this queue, in seconds since epoch.
prometheus_remote_storage_samples_bytes_totalThe total number of bytes of samples sent by the queue after compression.
prometheus_remote_storage_samples_dropped_totalTotal number of samples which were dropped after being read from the WAL before being sent via remote write.
prometheus_remote_storage_samples_failed_totalTotal number of samples which failed on send to remote storage, non-recoverable errors.
prometheus_remote_storage_samples_inSamples in to remote storage, compare to samples out for queue managers.
prometheus_remote_storage_samples_in_totalSamples in to remote storage, compare to samples out for queue managers.
prometheus_remote_storage_samples_pendingThe number of samples pending in the queues shards to be sent to the remote storage.
prometheus_remote_storage_samples_retried_totalTotal number of samples which failed on send to remote storage but were retried because the send error was recoverable.
prometheus_remote_storage_samples_totalTotal number of samples sent to remote storage.
prometheus_remote_storage_sent_batch_duration_secondsDuration of send calls to the remote storage.
prometheus_remote_storage_shard_capacityThe capacity of each shard of the queue used for parallel sending to the remote storage.
prometheus_remote_storage_shardsThe number of shards used for parallel sending to the remote storage.
prometheus_remote_storage_shards_desiredThe number of shards that the queues shard calculation wants to run based on the rate of samples in vs. samples out.
prometheus_remote_storage_shards_maxThe maximum number of shards that the queue is allowed to run.
prometheus_remote_storage_shards_minThe minimum number of shards that the queue is allowed to run.
prometheus_remote_storage_string_interner_zero_reference_releasesThe number of times release has been called for strings that are not interned.
prometheus_remote_storage_string_interner_zero_reference_releases_totalThe number of times release has been called for strings that are not interned.
prometheus_rule_evaluation_duration_secondsThe duration for a rule to execute.
prometheus_rule_evaluation_failures_totalThe total number of rule evaluation failures.
prometheus_rule_evaluations_totalThe total number of rule evaluations.
prometheus_rule_group_duration_secondsThe duration of rule group evaluations.
prometheus_rule_group_interval_secondsThe interval of a rule group.
prometheus_rule_group_iterations_missed_totalThe total number of rule group evaluations missed due to slow rule group evaluation.
prometheus_rule_group_iterations_totalThe total number of scheduled rule group evaluations, whether executed or missed.
prometheus_rule_group_last_duration_secondsThe duration of the last rule group evaluation.
prometheus_rule_group_last_evaluation_samplesThe number of samples returned during the last rule group evaluation.
prometheus_rule_group_last_evaluation_timestamp_secondsThe timestamp of the last rule group evaluation in seconds.
prometheus_rule_group_rulesThe number of rules.
prometheus_sd_consul_rpc_duration_secondsThe duration of a Consul RPC call in seconds.
prometheus_sd_consul_rpc_failures_totalThe number of Consul RPC call failures.
prometheus_sd_discovered_targetsCurrent number of discovered targets.
prometheus_sd_dns_lookup_failuresThe number of DNS-SD lookup failures.
prometheus_sd_dns_lookup_failures_totalThe number of DNS-SD lookup failures.
prometheus_sd_dns_lookupsThe number of DNS-SD lookups.
prometheus_sd_dns_lookups_totalThe number of DNS-SD lookups.
prometheus_sd_failed_configsCurrent number of service discovery configurations that failed to load.
prometheus_sd_file_read_errorsThe number of File-SD read errors.
prometheus_sd_file_read_errors_totalThe number of File-SD read errors.
prometheus_sd_file_scan_duration_secondsThe duration of the File-SD scan in seconds.
prometheus_sd_kubernetes_events_totalThe number of Kubernetes events handled.
prometheus_sd_kubernetes_http_request_duration_secondsSummary of latencies for HTTP requests to the Kubernetes API by endpoint.
prometheus_sd_kubernetes_http_request_totalTotal number of HTTP requests to the Kubernetes API by status code.
prometheus_sd_kubernetes_workqueue_depthCurrent depth of the work queue.
prometheus_sd_kubernetes_workqueue_items_totalTotal number of items added to the work queue.
prometheus_sd_kubernetes_workqueue_latency_secondsHow long an item stays in the work queue.
prometheus_sd_kubernetes_workqueue_longest_running_processor_secondsDuration of the longest running processor in the work queue.
prometheus_sd_kubernetes_workqueue_unfinished_work_secondsHow long an item has remained unfinished in the work queue.
prometheus_sd_kubernetes_workqueue_work_duration_secondsHow long processing an item from the work queue takes.
prometheus_sd_received_updates_totalTotal number of update events received from the SD providers.
prometheus_sd_updates_totalTotal number of update events sent to the SD consumers.
prometheus_target_interval_length_secondsActual intervals between scrapes.
prometheus_target_metadata_cache_bytesThe number of bytes that are currently used for storing metric metadata in the cache
prometheus_target_metadata_cache_entriesTotal number of metric metadata entries in the cache
prometheus_target_scrape_pool_exceeded_label_limitsTotal number of times scrape pools hit the label limits, during sync or config reload.
prometheus_target_scrape_pool_exceeded_target_limitTotal number of times scrape pools hit the target limit, during sync or config reload.
prometheus_target_scrape_pool_exceeded_target_limit_totalTotal number of times scrape pools hit the target limit, during sync or config reload.
prometheus_target_scrape_pool_reloadsTotal number of scrape pool reloads.
prometheus_target_scrape_pool_reloads_failedTotal number of failed scrape pool reloads.
prometheus_target_scrape_pool_reloads_failed_totalTotal number of failed scrape pool reloads.
prometheus_target_scrape_pool_reloads_totalTotal number of scrape pool reloads.
prometheus_target_scrape_pool_sync_totalTotal number of syncs that were executed on a scrape pool.
prometheus_target_scrape_pool_targetsCurrent number of targets in this scrape pool.
prometheus_target_scrape_poolsTotal number of scrape pool creation attempts.
prometheus_target_scrape_pools_failedTotal number of scrape pool creations that failed.
prometheus_target_scrape_pools_failed_totalTotal number of scrape pool creations that failed.
prometheus_target_scrape_pools_totalTotal number of scrape pool creation attempts.
prometheus_target_scrapes_cache_flush_forcedHow many times a scrape cache was flushed due to getting big while scrapes are failing.
prometheus_target_scrapes_cache_flush_forced_totalHow many times a scrape cache was flushed due to getting big while scrapes are failing.
prometheus_target_scrapes_exceeded_body_size_limitTotal number of scrapes that hit the body size limit
prometheus_target_scrapes_exceeded_sample_limitTotal number of scrapes that hit the sample limit and were rejected.
prometheus_target_scrapes_exceeded_sample_limit_totalTotal number of scrapes that hit the sample limit and were rejected.
prometheus_target_scrapes_exemplar_out_of_orderTotal number of exemplar rejected due to not being out of the expected order.
prometheus_target_scrapes_exemplar_out_of_order_totalTotal number of exemplar rejected due to not being out of the expected order.
prometheus_target_scrapes_sample_duplicate_timestampTotal number of samples rejected due to duplicate timestamps but different values.
prometheus_target_scrapes_sample_duplicate_timestamp_totalTotal number of samples rejected due to duplicate timestamps but different values.
prometheus_target_scrapes_sample_out_of_boundsTotal number of samples rejected due to timestamp falling outside of the time bounds.
prometheus_target_scrapes_sample_out_of_bounds_totalTotal number of samples rejected due to timestamp falling outside of the time bounds.
prometheus_target_scrapes_sample_out_of_orderTotal number of samples rejected due to not being out of the expected order.
prometheus_target_scrapes_sample_out_of_order_totalTotal number of samples rejected due to not being out of the expected order.
prometheus_target_sync_length_secondsActual interval to sync the scrape pool.
prometheus_template_text_expansion_failuresThe total number of template text expansion failures.
prometheus_template_text_expansion_failures_totalThe total number of template text expansion failures.
prometheus_template_text_expansionsThe total number of template text expansions.
prometheus_template_text_expansions_totalThe total number of template text expansions.
prometheus_treecache_watcher_goroutinesThe current number of watcher goroutines.
prometheus_treecache_zookeeper_failures_totalThe total number of ZooKeeper failures.
prometheus_tsdb_blocks_loadedNumber of currently loaded data blocks
prometheus_tsdb_checkpoint_creations_failed_totalTotal number of checkpoint creations that failed.
prometheus_tsdb_checkpoint_creations_totalTotal number of checkpoint creations attempted.
prometheus_tsdb_checkpoint_deletions_failed_totalTotal number of checkpoint deletions that failed.
prometheus_tsdb_checkpoint_deletions_totalTotal number of checkpoint deletions attempted.
prometheus_tsdb_compaction_chunk_range_secondsFinal time range of chunks on their first compaction
prometheus_tsdb_compaction_chunk_samplesFinal number of samples on their first compaction
prometheus_tsdb_compaction_chunk_size_bytesFinal size of chunks on their first compaction
prometheus_tsdb_compaction_duration_secondsDuration of compaction runs
prometheus_tsdb_compaction_populating_blockSet to 1 when a block is currently being written to the disk.
prometheus_tsdb_compactions_failed_totalTotal number of compactions that failed for the partition.
prometheus_tsdb_compactions_skipped_totalTotal number of skipped compactions due to disabled auto compaction.
prometheus_tsdb_compactions_totalTotal number of compactions that were executed for the partition.
prometheus_tsdb_compactions_triggered_totalTotal number of triggered compactions for the partition.
prometheus_tsdb_data_replay_duration_secondsTime taken to replay the data on disk.
prometheus_tsdb_head_active_appendersNumber of currently active appender transactions
prometheus_tsdb_head_chunksTotal number of chunks in the head block.
prometheus_tsdb_head_chunks_created_totalTotal number of chunks created in the head
prometheus_tsdb_head_chunks_removed_totalTotal number of chunks removed in the head
prometheus_tsdb_head_gc_duration_secondsRuntime of garbage collection in the head block.
prometheus_tsdb_head_max_timeMaximum timestamp of the head block. The unit is decided by the library consumer.
prometheus_tsdb_head_max_time_secondsMaximum timestamp of the head block.
prometheus_tsdb_head_min_timeMinimum time bound of the head block. The unit is decided by the library consumer.
prometheus_tsdb_head_min_time_secondsMinimum time bound of the head block.
prometheus_tsdb_head_samples_appended_totalTotal number of appended samples.
prometheus_tsdb_head_seriesTotal number of series in the head block.
prometheus_tsdb_head_series_created_totalTotal number of series created in the head
prometheus_tsdb_head_series_not_found_totalTotal number of requests for series that were not found.
prometheus_tsdb_head_series_removed_totalTotal number of series removed in the head
prometheus_tsdb_head_truncations_failed_totalTotal number of head truncations that failed.
prometheus_tsdb_head_truncations_totalTotal number of head truncations attempted.
prometheus_tsdb_isolation_high_watermarkThe highest TSDB append ID that has been given out.
prometheus_tsdb_isolation_low_watermarkThe lowest TSDB append ID that is still referenced.
prometheus_tsdb_lowest_timestampLowest timestamp value stored in the database. The unit is decided by the library consumer.
prometheus_tsdb_lowest_timestamp_secondsLowest timestamp value stored in the database.
prometheus_tsdb_mmap_chunk_corruptions_totalTotal number of memory-mapped chunk corruptions.
prometheus_tsdb_out_of_bound_samples_totalTotal number of out of bound samples ingestion failed attempts.
prometheus_tsdb_out_of_order_exemplars_totalTotal number of out of order exemplars ingestion failed attempts.
prometheus_tsdb_out_of_order_samples_totalTotal number of out of order samples ingestion failed attempts.
prometheus_tsdb_reloads_failures_totalNumber of times the database failed to reloadBlocks block data from disk.
prometheus_tsdb_reloads_totalNumber of times the database reloaded block data from disk.
prometheus_tsdb_retention_limit_bytesMax number of bytes to be retained in the tsdb blocks, configured 0 means disabled
prometheus_tsdb_size_retentions_totalThe number of times that blocks were deleted because the maximum number of bytes was exceeded.
prometheus_tsdb_storage_blocks_bytesThe number of bytes that are currently used for local storage by all blocks.
prometheus_tsdb_symbol_table_size_bytesSize of symbol table in memory for loaded blocks
prometheus_tsdb_time_retentions_totalThe number of times that blocks were deleted because the maximum time limit was exceeded.
prometheus_tsdb_tombstone_cleanup_secondsThe time taken to recompact blocks to remove tombstones.
prometheus_tsdb_vertical_compactions_totalTotal number of compactions done on overlapping blocks.
prometheus_tsdb_wal_completed_pages_totalTotal number of completed pages.
prometheus_tsdb_wal_corruptions_totalTotal number of WAL corruptions.
prometheus_tsdb_wal_fsync_duration_secondsDuration of WAL fsync.
prometheus_tsdb_wal_page_flushes_totalTotal number of page flushes.
prometheus_tsdb_wal_segment_currentWAL segment index that TSDB is currently writing to.
prometheus_tsdb_wal_truncate_duration_secondsDuration of WAL truncation.
prometheus_tsdb_wal_truncations_failed_totalTotal number of WAL truncations that failed.
prometheus_tsdb_wal_truncations_totalTotal number of WAL truncations attempted.
prometheus_tsdb_wal_writes_failed_totalTotal number of WAL writes that failed.
prometheus_wal_watcher_current_segmentCurrent segment the WAL watcher is reading records from.
prometheus_wal_watcher_record_decode_failures_totalNumber of records read by the WAL watcher that resulted in an error when decoding.
prometheus_wal_watcher_records_read_totalNumber of records read by the WAL watcher from the WAL.
prometheus_wal_watcher_samples_sent_pre_tailing_totalNumber of sample records read by the WAL watcher and sent to remote write during replay of existing WAL.
prometheus_web_federation_errors_totalTotal number of errors that occurred while sending federation responses.
prometheus_web_federation_warnings_totalTotal number of warnings that occurred while sending federation responses.
promhttp_metric_handler_requests_in_flightCurrent number of scrapes being served.
promhttp_metric_handler_requests_totalTotal number of scrapes by HTTP status code.
push_failure_time_secondsLast Unix time when changing this group in the Pushgateway failed.
push_time_secondsLast Unix time when changing this group in the Pushgateway succeeded.
pushgateway_build_infoA metric with a constant '1' value labeled by version, revision, branch, and goversion from which pushgateway was built.
pushgateway_http_push_duration_secondsHTTP request duration for pushes to the Pushgateway.
pushgateway_http_push_size_bytesHTTP request size for pushes to the Pushgateway.
pushgateway_http_requests_totalTotal HTTP requests processed by the Pushgateway, excluding scrapes.
querier_index_cache_corruptionsThe number of cache corruptions for the index cache.
querier_index_cache_encode_errorsThe number of errors for the index cache while encoding the body.
querier_index_cache_getsThe number of gets for the index cache.
querier_index_cache_hitsThe number of cache hits for the index cache.
querier_index_cache_putsThe number of puts for the index cache.
rabbitmq_acknowledged_published_total
rabbitmq_acknowledged_total
rabbitmq_alarms_file_descriptor_limitis 1 if file descriptor limit alarm is in effect
rabbitmq_alarms_free_disk_space_watermarkis 1 if free disk space watermark alarm is in effect
rabbitmq_alarms_memory_used_watermarkis 1 if VM memory watermark alarm is in effect
rabbitmq_auth_attempts_failed_totalTotal number of failed authentication attempts
rabbitmq_auth_attempts_succeeded_totalTotal number of successful authentication attempts
rabbitmq_auth_attempts_totalTotal number of authorization attempts
rabbitmq_build_infoRabbitMQ & Erlang/OTP version info
rabbitmq_channel_acks_uncommittedMessage acknowledgements in a transaction not yet committed
rabbitmq_channel_consumersConsumers on a channel
rabbitmq_channel_get_ack_totalTotal number of messages fetched with basic.get in manual acknowledgement mode
rabbitmq_channel_get_empty_totalTotal number of times basic.get operations fetched no message
rabbitmq_channel_get_totalTotal number of messages fetched with basic.get in automatic acknowledgement mode
rabbitmq_channel_messages_acked_totalTotal number of messages acknowledged by consumers
rabbitmq_channel_messages_confirmed_totalTotal number of messages published into an exchange and confirmed on the channel
rabbitmq_channel_messages_delivered_ack_totalTotal number of messages delivered to consumers in manual acknowledgement mode
rabbitmq_channel_messages_delivered_totalTotal number of messages delivered to consumers in automatic acknowledgement mode
rabbitmq_channel_messages_published_totalTotal number of messages published into an exchange on a channel
rabbitmq_channel_messages_redelivered_totalTotal number of messages redelivered to consumers
rabbitmq_channel_messages_unackedDelivered but not yet acknowledged messages
rabbitmq_channel_messages_uncommittedMessages received in a transaction but not yet committed
rabbitmq_channel_messages_unconfirmedPublished but not yet confirmed messages
rabbitmq_channel_messages_unroutable_dropped_totalTotal number of messages published as non-mandatory into an exchange and dropped as unroutable
rabbitmq_channel_messages_unroutable_returned_totalTotal number of messages published as mandatory into an exchange and returned to the publisher as unroutable
rabbitmq_channel_prefetchTotal limit of unacknowledged messages for all consumers on a channel
rabbitmq_channel_process_reductions_totalTotal number of channel process reductions
rabbitmq_channels
rabbitmq_channels_closed_totalTotal number of channels closed
rabbitmq_channels_opened_totalTotal number of channels opened
rabbitmq_connection_channelsChannels on a connection
rabbitmq_connection_incoming_bytes_totalTotal number of bytes received on a connection
rabbitmq_connection_incoming_packets_totalTotal number of packets received on a connection
rabbitmq_connection_outgoing_bytes_totalTotal number of bytes sent on a connection
rabbitmq_connection_outgoing_packets_totalTotal number of packets sent on a connection
rabbitmq_connection_pending_packetsNumber of packets waiting to be sent on a connection
rabbitmq_connection_process_reductions_totalTotal number of connection process reductions
rabbitmq_connections
rabbitmq_connections_closed_totalTotal number of connections closed or terminated
rabbitmq_connections_opened_totalTotal number of connections opened
rabbitmq_consumed_total
rabbitmq_consumer_prefetchLimit of unacknowledged messages for each consumer
rabbitmq_consumersConsumers currently connected
rabbitmq_disk_space_available_bytesDisk space available in bytes
rabbitmq_disk_space_available_limit_bytesFree disk space low watermark in bytes
rabbitmq_erlang_gc_reclaimed_bytes_totalTotal number of bytes of memory reclaimed by Erlang garbage collector
rabbitmq_erlang_gc_runs_totalTotal number of Erlang garbage collector runs
rabbitmq_erlang_net_ticktime_secondsInter-node heartbeat interval
rabbitmq_erlang_processes_limitErlang processes limit
rabbitmq_erlang_processes_usedErlang processes used
rabbitmq_erlang_scheduler_context_switches_totalTotal number of Erlang scheduler context switches
rabbitmq_erlang_scheduler_run_queueErlang scheduler run queue
rabbitmq_erlang_uptime_secondsNode uptime
rabbitmq_failed_to_publish_total
rabbitmq_global_consumersCurrent number of consumers
rabbitmq_global_messages_acknowledged_totalTotal number of messages acknowledged by consumers
rabbitmq_global_messages_confirmed_totalTotal number of messages confirmed to publishers
rabbitmq_global_messages_delivered_consume_auto_ack_totalTotal number of messages delivered to consumers using basic.consume with automatic acknowledgment
rabbitmq_global_messages_delivered_consume_manual_ack_totalTotal number of messages delivered to consumers using basic.consume with manual acknowledgment
rabbitmq_global_messages_delivered_get_auto_ack_totalTotal number of messages delivered to consumers using basic.get with automatic acknowledgment
rabbitmq_global_messages_delivered_get_manual_ack_totalTotal number of messages delivered to consumers using basic.get with manual acknowledgment
rabbitmq_global_messages_delivered_totalTotal number of messages delivered to consumers
rabbitmq_global_messages_get_empty_totalTotal number of times basic.get operations fetched no message
rabbitmq_global_messages_received_confirm_totalTotal number of messages received from publishers expecting confirmations
rabbitmq_global_messages_received_totalTotal number of messages received from publishers
rabbitmq_global_messages_redelivered_totalTotal number of messages redelivered to consumers
rabbitmq_global_messages_routed_totalTotal number of messages routed to queues or streams
rabbitmq_global_messages_unroutable_dropped_totalTotal number of messages published as non-mandatory into an exchange and dropped as unroutable
rabbitmq_global_messages_unroutable_returned_totalTotal number of messages published as mandatory into an exchange and returned to the publisher as unroutable
rabbitmq_global_publishersCurrent number of publishers
rabbitmq_identity_infoRabbitMQ node & cluster identity info
rabbitmq_io_open_attempt_ops_totalTotal number of file open attempts
rabbitmq_io_open_attempt_time_seconds_totalTotal file open attempts time
rabbitmq_io_read_bytes_totalTotal number of I/O bytes read
rabbitmq_io_read_ops_totalTotal number of I/O read operations
rabbitmq_io_read_time_seconds_totalTotal I/O read time
rabbitmq_io_reopen_ops_totalTotal number of times files have been reopened
rabbitmq_io_seek_ops_totalTotal number of I/O seek operations
rabbitmq_io_seek_time_seconds_totalTotal I/O seek time
rabbitmq_io_sync_ops_totalTotal number of I/O sync operations
rabbitmq_io_sync_time_seconds_totalTotal I/O sync time
rabbitmq_io_write_bytes_totalTotal number of I/O bytes written
rabbitmq_io_write_ops_totalTotal number of I/O write operations
rabbitmq_io_write_time_seconds_totalTotal I/O write time
rabbitmq_msg_store_read_totalTotal number of Message Store read operations
rabbitmq_msg_store_write_totalTotal number of Message Store write operations
rabbitmq_not_acknowledged_published_total
rabbitmq_process_max_fdsOpen file descriptors limit
rabbitmq_process_max_tcp_socketsOpen TCP sockets limit
rabbitmq_process_open_fdsOpen file descriptors
rabbitmq_process_open_tcp_socketsOpen TCP sockets
rabbitmq_process_resident_memory_bytesMemory used in bytes
rabbitmq_published_total
rabbitmq_queue_consumer_capacityConsumer capacity
rabbitmq_queue_consumer_utilisationSame as consumer capacity
rabbitmq_queue_consumersConsumers on a queue
rabbitmq_queue_disk_reads_totalTotal number of times queue read messages from disk
rabbitmq_queue_disk_writes_totalTotal number of times queue wrote messages to disk
rabbitmq_queue_index_journal_write_ops_totalTotal number of Queue Index Journal write operations
rabbitmq_queue_index_read_ops_totalTotal number of Queue Index read operations
rabbitmq_queue_index_write_ops_totalTotal number of Queue Index write operations
rabbitmq_queue_messagesSum of ready and unacknowledged messages - total queue depth
rabbitmq_queue_messages_bytesSize in bytes of ready and unacknowledged messages
rabbitmq_queue_messages_paged_outMessages paged out to disk
rabbitmq_queue_messages_paged_out_bytesSize in bytes of messages paged out to disk
rabbitmq_queue_messages_persistentPersistent messages
rabbitmq_queue_messages_persistent_bytesSize in bytes of persistent messages
rabbitmq_queue_messages_published_totalTotal number of messages published to queues
rabbitmq_queue_messages_ramReady and unacknowledged messages stored in memory
rabbitmq_queue_messages_ram_bytesSize of ready and unacknowledged messages stored in memory
rabbitmq_queue_messages_readyMessages ready to be delivered to consumers
rabbitmq_queue_messages_ready_bytesSize in bytes of ready messages
rabbitmq_queue_messages_ready_ramReady messages stored in memory
rabbitmq_queue_messages_unackedMessages delivered to consumers but not yet acknowledged
rabbitmq_queue_messages_unacked_bytesSize in bytes of all unacknowledged messages
rabbitmq_queue_messages_unacked_ramUnacknowledged messages stored in memory
rabbitmq_queue_process_memory_bytesMemory in bytes used by the Erlang queue process
rabbitmq_queue_process_reductions_totalTotal number of queue process reductions
rabbitmq_queuesQueues available
rabbitmq_queues_created_totalTotal number of queues created
rabbitmq_queues_declared_totalTotal number of queues declared
rabbitmq_queues_deleted_totalTotal number of queues deleted
rabbitmq_raft_entry_commit_latency_secondsTime taken for a log entry to be committed
rabbitmq_raft_log_commit_indexRaft log commit index
rabbitmq_raft_log_last_applied_indexRaft log last applied index
rabbitmq_raft_log_last_written_indexRaft log last written index
rabbitmq_raft_log_snapshot_indexRaft log snapshot index
rabbitmq_raft_term_totalCurrent Raft term number
rabbitmq_rejected_total
rabbitmq_resident_memory_limit_bytesMemory high watermark in bytes
rabbitmq_schema_db_disk_tx_totalTotal number of Schema DB disk transactions
rabbitmq_schema_db_ram_tx_totalTotal number of Schema DB memory transactions
rabbitmq_unrouted_published_total
replicateProject_total
spring_integration_channelsThe number of message channels
spring_integration_handlersThe number of message handlers
spring_integration_sourcesThe number of message sources
spring_rabbitmq_listener_secondsSpring RabbitMQ Listener
spring_rabbitmq_listener_seconds_maxSpring RabbitMQ Listener
system_cpu_countThe number of processors available to the Java virtual machine
system_cpu_usageThe "recent cpu usage" for the whole system
system_load_average_1mThe sum of the number of runnable entities queued to available processors and the number of runnable entities running on the available processors averaged over a period of time
telemetry_scrape_duration_secondsScrape duration
telemetry_scrape_encoded_size_bytesScrape size, encoded
telemetry_scrape_size_bytesScrape size, not encoded
tomcat_sessions_active_current_sessions
tomcat_sessions_active_max_sessions
tomcat_sessions_alive_max_seconds
tomcat_sessions_created_sessions_total
tomcat_sessions_expired_sessions_total
tomcat_sessions_rejected_sessions_total
Last updated on 3/21/2023
← Metrics & MonitoringBackup →
meshcloud
Docs
User DocumentationOperator Documentation
Community & Follow us
TwitterFacebookLinkedInXING
More
Release NotesGitHub
Copyright © 2023 meshcloud GmbH