mysql.binlog.cache_disk_use (gauge) | The number of transactions that used the temporary binary log cache but that exceeded the value of binlog_cache_size and used a temporary file to store statements from the transaction. Shown as transaction |
mysql.binlog.cache_use (gauge) | The number of transactions that used the binary log cache. Shown as transaction |
mysql.binlog.disk_use (gauge) | Total binary log file size. Shown as byte |
mysql.galera.wsrep_cert_deps_distance (gauge) | Shows the average distance between the lowest and highest sequence number, or seqno, values that the node can possibly apply in parallel. |
mysql.galera.wsrep_cluster_size (gauge) | The current number of nodes in the Galera cluster. Shown as node |
mysql.galera.wsrep_flow_control_paused (gauge) | Shows the fraction of the time, since FLUSH STATUS was last called, that the node paused due to Flow Control. Shown as fraction |
mysql.galera.wsrep_flow_control_paused_ns (count) | Shows the pause time due to Flow Control, in nanoseconds. Shown as nanosecond |
mysql.galera.wsrep_flow_control_recv (count) | Shows the number of times the galera node has received a pausing Flow Control message from others |
mysql.galera.wsrep_flow_control_sent (count) | Shows the number of times the galera node has sent a pausing Flow Control message to others |
mysql.galera.wsrep_local_cert_failures (count) | Total number of local transactions that failed certification test. |
mysql.galera.wsrep_local_recv_queue (gauge) | Shows the current (instantaneous) size of the local received queue. |
mysql.galera.wsrep_local_recv_queue_avg (gauge) | Shows the average size of the local received queue since the last FLUSH STATUS query. |
mysql.galera.wsrep_local_send_queue (gauge) | Show the current (instantaneous) size of the send queue length since the last FLUSH STATUS query. |
mysql.galera.wsrep_local_send_queue_avg (gauge) | Show an average for the send queue length since the last FLUSH STATUS query. |
mysql.galera.wsrep_local_state (gauge) | Internal Galera cluster state number |
mysql.galera.wsrep_received (gauge) | Total number of write-sets received from other nodes. |
mysql.galera.wsrep_received_bytes (gauge) | Total size (in bytes) of writesets received from other nodes. |
mysql.galera.wsrep_replicated_bytes (gauge) | Total size (in bytes) of writesets sent to other nodes. |
mysql.info.schema.size (gauge) | Size of schemas in MiB Shown as mebibyte |
mysql.info.table.data_size (gauge) | Size of tables data in MiB Shown as mebibyte |
mysql.info.table.index_size (gauge) | Size of tables index in MiB Shown as mebibyte |
mysql.info.table.rows.changed (count) | Total number of rows changed per table (Percona userstat only) Shown as row |
mysql.info.table.rows.read (count) | Total number of rows read per table (Percona userstat only) Shown as row |
mysql.innodb.active_transactions (gauge) | The number of active transactions on InnoDB tables. Shown as operation |
mysql.innodb.buffer_pool_data (gauge) | The total number of bytes in the InnoDB buffer pool containing data. The number includes both dirty and clean pages. Shown as byte |
mysql.innodb.buffer_pool_dirty (gauge) | The total current number of bytes held in dirty pages in the InnoDB buffer pool. Shown as byte |
mysql.innodb.buffer_pool_free (gauge) | The number of free bytes in the InnoDB Buffer Pool. Shown as byte |
mysql.innodb.buffer_pool_pages_data (gauge) | The number of pages in the InnoDB buffer pool containing data. The number includes both dirty and clean pages. Shown as page |
mysql.innodb.buffer_pool_pages_dirty (gauge) | The current number of dirty pages in the InnoDB buffer pool. Shown as page |
mysql.innodb.buffer_pool_pages_flushed (gauge) | The number of requests to flush pages from the InnoDB buffer pool. Shown as page |
mysql.innodb.buffer_pool_pages_free (gauge) | The number of free pages in the InnoDB buffer pool. Shown as page |
mysql.innodb.buffer_pool_pages_total (gauge) | The total size of the InnoDB buffer pool, in pages. Shown as page |
mysql.innodb.buffer_pool_read_ahead (gauge) | The number of pages read into the InnoDB buffer pool by the read-ahead background thread. Shown as page |
mysql.innodb.buffer_pool_read_ahead_evicted (gauge) | The number of pages read into the InnoDB buffer pool by the read-ahead background thread that were subsequently evicted without having been accessed by queries. Shown as page |
mysql.innodb.buffer_pool_read_ahead_rnd (gauge) | The number of random read-aheads initiated by InnoDB. This happens when a query scans a large portion of a table but in random order. Shown as operation |
mysql.innodb.buffer_pool_read_requests (gauge) | The number of logical read requests. Shown as read |
mysql.innodb.buffer_pool_reads (gauge) | The number of logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk. Shown as read |
mysql.innodb.buffer_pool_total (gauge) | The total number of bytes in the InnoDB Buffer Pool. Shown as byte |
mysql.innodb.buffer_pool_used (gauge) | The number of used bytes in the InnoDB Buffer Pool. Shown as byte |
mysql.innodb.buffer_pool_utilization (gauge) | The utilization of the InnoDB Buffer Pool. Shown as fraction |
mysql.innodb.buffer_pool_wait_free (count) | When InnoDB needs to read or create a page and no clean pages are available, InnoDB flushes some dirty pages first and waits for that operation to finish. This counter counts instances of these waits. Shown as wait |
mysql.innodb.buffer_pool_write_requests (gauge) | The number of writes done to the InnoDB buffer pool. Shown as write |
mysql.innodb.checkpoint_age (gauge) | Checkpoint age as shown in the LOG section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.current_row_locks (gauge) | The number of current row locks. Shown as lock |
mysql.innodb.current_transactions (gauge) | Current InnoDB transactions Shown as transaction |
mysql.innodb.data_fsyncs (gauge) | The number of fsync() operations per second. Shown as operation |
mysql.innodb.data_pending_fsyncs (gauge) | The current number of pending fsync() operations. Shown as operation |
mysql.innodb.data_pending_reads (gauge) | The current number of pending reads. Shown as read |
mysql.innodb.data_pending_writes (gauge) | The current number of pending writes. Shown as write |
mysql.innodb.data_read (gauge) | The amount of data read per second. Shown as byte |
mysql.innodb.data_reads (gauge) | The rate of data reads. Shown as read |
mysql.innodb.data_writes (gauge) | The rate of data writes. Shown as write |
mysql.innodb.data_written (gauge) | The amount of data written per second. Shown as byte |
mysql.innodb.dblwr_pages_written (gauge) | The number of pages written per second to the doublewrite buffer. Shown as page |
mysql.innodb.dblwr_writes (gauge) | The number of doublewrite operations performed per second. Shown as byte |
mysql.innodb.deadlocks (count) | The number of deadlocks. Shown as lock |
mysql.innodb.hash_index_cells_total (gauge) | Total number of cells of the adaptive hash index |
mysql.innodb.hash_index_cells_used (gauge) | Number of used cells of the adaptive hash index |
mysql.innodb.history_list_length (gauge) | History list length as shown in the TRANSACTIONS section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.ibuf_free_list (gauge) | Insert buffer free list, as shown in the INSERT BUFFER AND ADAPTIVE HASH INDEX section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.ibuf_merged (gauge) | Insert buffer and adaptative hash index merged Shown as operation |
mysql.innodb.ibuf_merged_delete_marks (gauge) | Insert buffer and adaptative hash index merged delete marks Shown as operation |
mysql.innodb.ibuf_merged_deletes (gauge) | Insert buffer and adaptative hash index merged delete Shown as operation |
mysql.innodb.ibuf_merged_inserts (gauge) | Insert buffer and adaptative hash index merged inserts Shown as operation |
mysql.innodb.ibuf_merges (gauge) | Insert buffer and adaptative hash index merges Shown as operation |
mysql.innodb.ibuf_segment_size (gauge) | Insert buffer segment size, as shown in the INSERT BUFFER AND ADAPTIVE HASH INDEX section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.ibuf_size (gauge) | Insert buffer size, as shown in the INSERT BUFFER AND ADAPTIVE HASH INDEX section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.lock_structs (gauge) | Lock structs Shown as operation |
mysql.innodb.locked_tables (gauge) | Locked tables Shown as operation |
mysql.innodb.log_waits (gauge) | The number of times that the log buffer was too small and a wait was required for it to be flushed before continuing. Shown as wait |
mysql.innodb.log_write_requests (gauge) | The number of write requests for the InnoDB redo log. Shown as write |
mysql.innodb.log_writes (gauge) | The number of physical writes to the InnoDB redo log file. Shown as write |
mysql.innodb.lsn_current (gauge) | Log sequence number as shown in the LOG section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.lsn_flushed (gauge) | Flushed up to log sequence number as shown in the LOG section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.lsn_last_checkpoint (gauge) | Log sequence number last checkpoint as shown in the LOG section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.mem_adaptive_hash (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. Shown as byte |
mysql.innodb.mem_additional_pool (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. Only available in MySQL 5.6. Shown as byte |
mysql.innodb.mem_dictionary (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. Shown as byte |
mysql.innodb.mem_file_system (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.mem_lock_system (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.mem_page_hash (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.mem_recovery_system (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.mem_total (gauge) | As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output. Shown as byte |
mysql.innodb.mutex_os_waits (gauge) | The rate of mutex OS waits. Only available in MySQL 5.6 and 5.7. Shown as event |
mysql.innodb.mutex_spin_rounds (gauge) | The rate of mutex spin rounds. Only available in MySQL 5.6 and 5.7. Shown as event |
mysql.innodb.mutex_spin_waits (gauge) | The rate of mutex spin waits. Only available in MySQL 5.6 and 5.7. Shown as event |
mysql.innodb.os_file_fsyncs (gauge) | (Delta) The total number of fsync() operations performed by InnoDB. Shown as operation |
mysql.innodb.os_file_reads (gauge) | (Delta) The total number of files reads performed by read threads within InnoDB. Shown as operation |
mysql.innodb.os_file_writes (gauge) | (Delta) The total number of file writes performed by write threads within InnoDB. Shown as operation |
mysql.innodb.os_log_fsyncs (gauge) | The rate of fsync writes to the log file. Shown as write |
mysql.innodb.os_log_pending_fsyncs (gauge) | Number of pending InnoDB log fsync (sync-to-disk) requests. Shown as operation |
mysql.innodb.os_log_pending_writes (gauge) | Number of pending InnoDB log writes. Shown as write |
mysql.innodb.os_log_written (gauge) | Number of bytes written to the InnoDB log. Shown as byte |
mysql.innodb.pages_created (gauge) | Number of InnoDB pages created. Shown as page |
mysql.innodb.pages_read (gauge) | Number of InnoDB pages read. Shown as page |
mysql.innodb.pages_written (gauge) | Number of InnoDB pages written. Shown as page |
mysql.innodb.pending_aio_log_ios (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.pending_aio_sync_ios (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.pending_buffer_pool_flushes (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Shown as flush |
mysql.innodb.pending_checkpoint_writes (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.pending_ibuf_aio_reads (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.pending_log_flushes (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Only available in MySQL 5.6 and 5.7. Shown as flush |
mysql.innodb.pending_log_writes (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Only available in MySQL 5.6 and 5.7. Shown as write |
mysql.innodb.pending_normal_aio_reads (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Shown as read |
mysql.innodb.pending_normal_aio_writes (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Shown as write |
mysql.innodb.queries_inside (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Shown as query |
mysql.innodb.queries_queued (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. Shown as query |
mysql.innodb.read_views (gauge) | As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.row_lock_current_waits (gauge) | The number of row locks currently being waited for by operations on InnoDB tables. |
mysql.innodb.row_lock_time (gauge) | Fraction of time spent (ms/s) acquiring row locks. Shown as fraction |
mysql.innodb.row_lock_waits (gauge) | The number of times per second a row lock had to be waited for. Shown as event |
mysql.innodb.rows_deleted (gauge) | Number of rows deleted from InnoDB tables. Shown as row |
mysql.innodb.rows_inserted (gauge) | Number of rows inserted into InnoDB tables. Shown as row |
mysql.innodb.rows_read (gauge) | Number of rows read from InnoDB tables. Shown as row |
mysql.innodb.rows_updated (gauge) | Number of rows updated in InnoDB tables. Shown as row |
mysql.innodb.s_lock_os_waits (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output |
mysql.innodb.s_lock_spin_rounds (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.s_lock_spin_waits (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output. Shown as wait |
mysql.innodb.semaphore_wait_time (gauge) | Semaphore wait time |
mysql.innodb.semaphore_waits (gauge) | The number semaphore currently being waited for by operations on InnoDB tables. |
mysql.innodb.tables_in_use (gauge) | Tables in use Shown as operation |
mysql.innodb.x_lock_os_waits (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output. Shown as wait |
mysql.innodb.x_lock_spin_rounds (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output. |
mysql.innodb.x_lock_spin_waits (gauge) | As shown in the SEMAPHORES section of the SHOW ENGINE INNODB STATUS output. Shown as wait |
mysql.myisam.key_buffer_bytes_unflushed (gauge) | MyISAM key buffer bytes unflushed. Shown as byte |
mysql.myisam.key_buffer_bytes_used (gauge) | MyISAM key buffer bytes used. Shown as byte |
mysql.myisam.key_buffer_size (gauge) | Size of the buffer used for index blocks. Shown as byte |
mysql.myisam.key_read_requests (gauge) | The number of requests to read a key block from the MyISAM key cache. Shown as read |
mysql.myisam.key_reads (gauge) | The number of physical reads of a key block from disk into the MyISAM key cache. If key_reads is large, then your keybuffersize value is probably too small. The cache miss rate can be calculated as key_reads /key_read_requests . Shown as read |
mysql.myisam.key_write_requests (gauge) | The number of requests to write a key block to the MyISAM key cache. Shown as write |
mysql.myisam.key_writes (gauge) | The number of physical writes of a key block from the MyISAM key cache to disk. Shown as write |
mysql.net.aborted_clients (gauge) | The number of connections that were aborted because the client died without closing the connection properly. Shown as connection |
mysql.net.aborted_connects (gauge) | The number of failed attempts to connect to the MySQL server. Shown as connection |
mysql.net.connections (gauge) | The rate of connections to the server. Shown as connection |
mysql.net.max_connections (gauge) | The maximum number of connections that have been in use simultaneously since the server started. Shown as connection |
mysql.net.max_connections_available (gauge) | The maximum permitted number of simultaneous client connections. Shown as connection |
mysql.performance.bytes_received (gauge) | The number of bytes received from all clients. Shown as byte |
mysql.performance.bytes_sent (gauge) | The number of bytes sent to all clients. Shown as byte |
mysql.performance.com_delete (gauge) | The rate of delete statements. Shown as query |
mysql.performance.com_delete_multi (gauge) | The rate of delete-multi statements. Shown as query |
mysql.performance.com_insert (gauge) | The rate of insert statements. Shown as query |
mysql.performance.com_insert_select (gauge) | The rate of insert-select statements. Shown as query |
mysql.performance.com_load (gauge) | The rate of load statements. Shown as query |
mysql.performance.com_replace (gauge) | The rate of replace statements. Shown as query |
mysql.performance.com_replace_select (gauge) | The rate of replace-select statements. Shown as query |
mysql.performance.com_select (gauge) | The rate of select statements. Shown as query |
mysql.performance.com_update (gauge) | The rate of update statements. Shown as query |
mysql.performance.com_update_multi (gauge) | The rate of update-multi. Shown as query |
mysql.performance.cpu_time (gauge) | Percentage of CPU time spent by MySQL. Shown as percent |
mysql.performance.created_tmp_disk_tables (gauge) | The rate of internal on-disk temporary tables created by second by the server while executing statements. Shown as table |
mysql.performance.created_tmp_files (gauge) | The rate of temporary files created by second. Shown as file |
mysql.performance.created_tmp_tables (gauge) | The rate of internal temporary tables created by second by the server while executing statements. Shown as table |
mysql.performance.digest_95th_percentile.avg_us (gauge) | Query response time 95th percentile per schema. Shown as microsecond |
mysql.performance.handler_commit (gauge) | The number of internal COMMIT statements. Shown as operation |
mysql.performance.handler_delete (gauge) | The number of internal DELETE statements. Shown as operation |
mysql.performance.handler_prepare (gauge) | The number of internal PREPARE statements. Shown as operation |
mysql.performance.handler_read_first (gauge) | The number of internal READ_FIRST statements. Shown as operation |
mysql.performance.handler_read_key (gauge) | The number of internal READ_KEY statements. Shown as operation |
mysql.performance.handler_read_next (gauge) | The number of internal READ_NEXT statements. Shown as operation |
mysql.performance.handler_read_prev (gauge) | The number of internal READ_PREV statements. Shown as operation |
mysql.performance.handler_read_rnd (gauge) | The number of internal READ_RND statements. Shown as operation |
mysql.performance.handler_read_rnd_next (gauge) | The number of internal READRNDNEXT statements. Shown as operation |
mysql.performance.handler_rollback (gauge) | The number of internal ROLLBACK statements. Shown as operation |
mysql.performance.handler_update (gauge) | The number of internal UPDATE statements. Shown as operation |
mysql.performance.handler_write (gauge) | The number of internal WRITE statements. Shown as operation |
mysql.performance.kernel_time (gauge) | Percentage of CPU time spent in kernel space by MySQL. Shown as percent |
mysql.performance.key_cache_utilization (gauge) | The key cache utilization ratio. Shown as fraction |
mysql.performance.max_prepared_stmt_count (gauge) | The maximum allowed prepared statements on the server. |
mysql.performance.open_files (gauge) | The number of open files. Shown as file |
mysql.performance.open_tables (gauge) | The number of of tables that are open. Shown as table |
mysql.performance.opened_tables (gauge) | The number of tables that have been opened. If opened_tables is big, your table_open_cache value is probably too small. Shown as table |
mysql.performance.prepared_stmt_count (gauge) | The current number of prepared statements. Shown as query |
mysql.performance.qcache.utilization (gauge) | Fraction of the query cache memory currently being used. Shown as fraction |
mysql.performance.qcache_free_blocks (gauge) | The number of free memory blocks in the query cache. Shown as block |
mysql.performance.qcache_free_memory (gauge) | The amount of free memory for the query cache. Shown as byte |
mysql.performance.qcache_hits (gauge) | The rate of query cache hits. Shown as hit |
mysql.performance.qcache_inserts (gauge) | The number of queries added to the query cache. Shown as query |
mysql.performance.qcache_lowmem_prunes (gauge) | The number of queries that were deleted from the query cache because of low memory. Shown as query |
mysql.performance.qcache_not_cached (gauge) | The number of noncached queries (not cacheable, or not cached due to the query_cache_type setting). Shown as query |
mysql.performance.qcache_queries_in_cache (gauge) | The number of queries registered in the query cache. Shown as query |
mysql.performance.qcache_size (gauge) | The amount of memory allocated for caching query results. Shown as byte |
mysql.performance.qcache_total_blocks (gauge) | The total number of blocks in the query cache. Shown as block |
mysql.performance.queries (gauge) | The rate of queries. Shown as query |
mysql.performance.query_run_time.avg (gauge) | Avg query response time per schema. Shown as microsecond |
mysql.performance.questions (gauge) | The rate of statements executed by the server. Shown as query |
mysql.performance.select_full_join (gauge) | The number of joins that perform table scans because they do not use indexes. If this value is not 0, you should carefully check the indexes of your tables. Shown as operation |
mysql.performance.select_full_range_join (gauge) | The number of joins that used a range search on a reference table. Shown as operation |
mysql.performance.select_range (gauge) | The number of joins that used ranges on the first table. This is normally not a critical issue even if the value is quite large. Shown as operation |
mysql.performance.select_range_check (gauge) | The number of joins without keys that check for key usage after each row. If this is not 0, you should carefully check the indexes of your tables. Shown as operation |
mysql.performance.select_scan (gauge) | The number of joins that did a full scan of the first table. Shown as operation |
mysql.performance.slow_queries (gauge) | The rate of slow queries (log queries that exceed a particular execution time). Shown as query |
mysql.performance.sort_merge_passes (gauge) | The number of merge passes that the sort algorithm has had to do. If this value is large, you should consider increasing the value of the sort_buffer_size system variable. Shown as operation |
mysql.performance.sort_range (gauge) | The number of sorts that were done using ranges. Shown as operation |
mysql.performance.sort_rows (gauge) | The number of sorted rows. Shown as operation |
mysql.performance.sort_scan (gauge) | The number of sorts that were done by scanning the table. Shown as operation |
mysql.performance.table_cache_hits (gauge) | The number of hits for open tables cache lookups. Shown as hit |
mysql.performance.table_cache_misses (gauge) | The number of misses for open tables cache lookups. Shown as miss |
mysql.performance.table_locks_immediate (gauge) | The number of times that a request for a table lock could be granted immediately. |
mysql.performance.table_locks_immediate.rate (gauge) | The rate of times that a request for a table lock could be granted immediately. |
mysql.performance.table_locks_waited (gauge) | The total number of times that a request for a table lock could not be granted immediately and a wait was needed. |
mysql.performance.table_locks_waited.rate (gauge) | The rate of times that a request for a table lock could not be granted immediately and a wait was needed. |
mysql.performance.table_open_cache (gauge) | The number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires. |
mysql.performance.thread_cache_size (gauge) | How many threads the server should cache for reuse. When a client disconnects, the client's threads are put in the cache if there are fewer than thread_cache_size threads there. Shown as byte |
mysql.performance.threads_cached (gauge) | The number of threads in the thread cache. Shown as thread |
mysql.performance.threads_connected (gauge) | The number of currently open connections. Shown as connection |
mysql.performance.threads_created (count) | The number of threads created to handle connections. If threads_created is big, you may want to increase the thread_cache_size value. Shown as thread |
mysql.performance.threads_running (gauge) | The number of threads that are not sleeping. Shown as thread |
mysql.performance.user_connections (gauge) | The number of user connections. Tags: processlist_db , processlist_host , processlist_state , processlist_user Shown as connection |
mysql.performance.user_time (gauge) | Percentage of CPU time spent in user space by MySQL. Shown as percent |
mysql.queries.count (count) | The total count of executed queries per normalized query and schema. (DBM only) Shown as query |
mysql.queries.errors (count) | The total count of queries run with an error per normalized query and schema. (DBM only) Shown as error |
mysql.queries.lock_time (count) | The total time spent waiting on locks per normalized query and schema. (DBM only) Shown as nanosecond |
mysql.queries.no_good_index_used (count) | The total count of queries which used a sub-optimal index per normalized query and schema. (DBM only) Shown as query |
mysql.queries.no_index_used (count) | The total count of queries which do not use an index per normalized query and schema. (DBM only) Shown as query |
mysql.queries.rows_affected (count) | The number of rows mutated per normalized query and schema. (DBM only) Shown as row |
mysql.queries.rows_examined (count) | The number of rows examined per normalized query and schema. (DBM only) Shown as row |
mysql.queries.rows_sent (count) | The number of rows sent per normalized query and schema. (DBM only) Shown as row |
mysql.queries.select_full_join (count) | The total count of full table scans on a joined table per normalized query and schema. (DBM only) |
mysql.queries.select_scan (count) | The total count of full table scans on the first table per normalized query and schema. (DBM only) |
mysql.queries.time (count) | The total query execution time per normalized query and schema. (DBM only) Shown as nanosecond |
mysql.replication.group.conflicts_detected (gauge) | The number of transactions that have not passed the conflict detection check. Shown as transaction |
mysql.replication.group.member_status (gauge) | Information about the node status in a group replication environment, always equal to 1. |
mysql.replication.group.transactions (gauge) | The number of transactions in the queue pending conflict detection checks. Shown as transaction |
mysql.replication.group.transactions_applied (gauge) | Number of transactions this member has received from the group and applied. Shown as transaction |
mysql.replication.group.transactions_check (gauge) | The number of transactions that have been checked for conflicts. Shown as transaction |
mysql.replication.group.transactions_in_applier_queue (gauge) | The number of transactions that this member has received from the replication group which are waiting to be applied. Shown as transaction |
mysql.replication.group.transactions_proposed (gauge) | The number of transactions which originated on this member and were sent to the group. Shown as transaction |
mysql.replication.group.transactions_rollback (gauge) | The number of transactions which originated on this member and were rolled back by the group. Shown as transaction |
mysql.replication.group.transactions_validating (gauge) | The number of transaction rows which can be used for certification, but have not been garbage collected. Shown as transaction |
mysql.replication.replicas_connected (gauge) | Number of replicas connected to a replication source. |
mysql.replication.seconds_behind_master (gauge) | The lag in seconds between the master and the slave. Shown as second |
mysql.replication.seconds_behind_source (gauge) | The lag in seconds between the source and the replica. Shown as second |
mysql.replication.slave_running (gauge) | Deprecated. Use service check mysql.replication.replica_running instead. A boolean showing if this server is a replication slave / master that is running. |
mysql.replication.slaves_connected (gauge) | Deprecated. Use mysql.replication.replicas_connected instead. Number of slaves connected to a replication master. |