MySQL is an open source relational database management system (RDBMS) based on Structured Query Language (SQL).
Prerequisites
- Create a user.
CREATE USER '<Username>'@'localhost' IDENTIFIED BY '<Password>';
- Grant minimum privileges to the user.
GRANT REPLICATION CLIENT ON *.* TO '<Username>'@'localhost';
GRANT PROCESS ON *.* TO '<Username>'@'localhost';
GRANT SELECT ON performance_schema.* TO '<Username>'@'localhost';
FLUSH PRIVILEGES;
@‘localhost’ is only for local connections. Use hostname/IP for remote connections.
Use the username and password to monitor MySQL.
For Virtual Machines, install the Linux Agent.
Configuring the credentials
Configure the credentials in the directory /opt/opsramp/agent/conf/app.d/creds.yaml
mysql:
- name: mysql
user: <username>
pwd: <Password>
encoding-type: plain
labels:
key1: val1
key2: val2
Configuring the application
Virtual machine
Configure the application in the directory /opt/opsramp/agent/conf/app/discovery/auto-detection.yaml
- name: mysql
instance-checks:
service-check:
- mysql
process-check:
- mysql
port-check:
- 3306
Docker environment
Configure the application in the directory /opt/opsramp/agent/conf/app/discovery/auto-container-detection.yaml
- name: mysql
container-checks:
image-check:
- mysql
port-check:
- 3306
Kubernetes environment
Configure the application in config.yaml
- name: mysql
container-checks:
image-check:
- mysql
port-check:
- 3306
Validate
Go to Resources under the Infrastructure tab to check if your resources are onboarded and the metrics are collected.
Supported metrics
OpsRamp Metric | Metric Display Name | Unit |
---|---|---|
mysql_performance_Qcache_inserts Number of queries added to the query cache | Performance Qcache Inserts | Queries / second |
mysql_performance_Table_locks_waited Total number of times a request for a table lock could not be granted and a wait was needed | Performance Table Locks Waited | Wait |
mysql_myisam_Key_buffer_bytes_used MyISAM key buffer bytes used | MyISAM Key Buffer Bytes Used | bytes |
mysql_performance_Open_tables Number of tables that are open. | Performance Open Tables | Tables |
mysql_net_Max_used_connections Maximum number of connections in use simultaneously since the server started | Net Max Used Connections | Connections |
mysql_performance_Com_delete_multi Rate of delete-multi statements | Performance DeleteMulti Statements | Queries / second |
mysql_performance_Slow_queries Rate of queries that have taken more than long_query_time | Performance Slow Queries | Queries / second |
mysql_myisam_Key_buffer_bytes_unflushed MyISAM key buffer bytes unflushed | MyISAM Key Buffer Bytes Unflushed | bytes |
mysql_performance_Bytes_sent Number of bytes sent to all clients | Performance Bytes Sent | bytes / second |
mysql_performance_Com_replace Rate of replace statements | Performance Replace Statements | Queries / second |
mysql_performance_Com_delete Rate of delete statements | Performance Delete Statements | Queries / second |
mysql_performance_Table_locks_waited_rate Total number of times a request for a table lock could not be granted and a wait was needed | Performance Table Locks Waited Rate | Waits / second |
mysql_performance_Threads_running Number of threads that are not sleeping | Performance Threads Running | Threads |
mysql_performance_Queries Rate of queries | Performance Queries | Queries / second |
mysql_net_Aborted_connects Number of failed attempts to connect to the MySQL server | Net Aborted Connects | Connections / second |
mysql_performance_Com_load Rate of load statements | Performance Load Statements | Queries / second |
mysql_performance_Qcache_lowmem_prunes Number of queries that were deleted from the query cache because of low memory | Performance Qcache LowMem Prunes | Queries / second |
mysql_performance_Created_tmp_tables Rate of internal temporary tables created by second by the server while executing statements | Performance Created Tmp Tables | Tables / second |
mysql_performance_Created_tmp_disk_tables Rate of internal on-disk temporary tables created by second by the server while executing statements | Performance Created Tmp Disk Tables | Tables / second |
mysql_myisam_Key_reads Number of physical reads of a key block from disk into the MyISAM key cache. If Key_reads is large, your key_buffer_size value is probably too small. The cache miss rate can be calculated as Key_reads/Key_read_requests. | MyISAM Key Reads | Reads / second |
mysql_performance_Com_replace_select Rate of replace-select statements | Performance ReplaceSelect Statements | Queries / second |
mysql_performance_Com_select Rate of select statements | Performance Select Statements | Queries / second |
mysql_performance_Bytes_received Number of bytes received from all clients | Performance Bytes Received | bytes / second |
mysql_myisam_Key_write_requests Number of requests to write a key block to the MyISAM key cache | MyISAM Key Write Requests | Writes / second |
mysql_myisam_Key_writes Number of physical writes of a key block from the MyISAM key cache to disk | MyISAM Key Writes | Writes / second |
mysql_performance_Com_insert Rate of insert statements | Performance Insert Statements | Queries / second |
mysql_performance_Threads_connected Number of currently open connections | Performance Threads Connected | Connections |
mysql_performance_Com_update_multi Rate of update-multi statement | Performance UpdateMulti Statements | Queries / second |
mysql_performance_Com_update Rate of update statements | Performance Update Statements | Queries / second |
mysql_net_Connections Rate of connections to the server | Net Connections | Connections / second |
mysql_performance_Com_insert_select Rate of insert-select statements | Performance InsertSelect Statements | Queries / second |
mysql_performance_Qcache_hits Rate of query cache hits | Performance Qcache Hits | Hits / second |
mysql_performance_Questions Rate of statements executed by the server | Performance Questions | Queries / second |
mysql_performance_Created_tmp_files Rate of temporary files created by second | Performance Created Tmp Files | Files / second |
mysql_myisam_Key_read_requests Number of requests to read a key block from the MyISAM key cache | MyISAM Key Read Requests | Reads / second |
mysql_performance_Open_files Number of open files | Performance Open Files | Files |
mysql_net_Aborted_clients Number of connections that were aborted because the client died without closing the connection properly | Net Aborted Clients | Connections / second |
mysql_performance_query_cache_size Amount of memory allocated for caching query results | Performance Query Cache Size | bytes |
mysql_performance_table_open_cache Number of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires | Performance Table Open Cache | Tables |
mysql_performance_Key_cache_utilization Key cache utilization ratio | Performance Key Cache Utilization | Fraction |
mysql_performance_thread_cache_size How many threads the server should cache for reuse. When a client disconnects, the client threads are put in the cache if there are fewer than thread_cache_size threads there | Performance Thread Cache Size | bytes |
mysql_myisam_key_buffer_size Size of the buffer used for index blocks | MyISAM Key Buffer Size | bytes |
mysql_net_max_connections Maximum permitted number of simultaneous client connections | Net Max Connections | Connections |
mysql_Innodb_buffer_pool_read_requests Number of logical read requests | InnoDB Buffer Pool Read Requests | Reads / second |
mysql_Innodb_Mutex_spin_waits Rate of InnoDB semaphore/mutex spin waits for the internal sync array | InnoDB Mutex Spin Waits | Events / second |
mysql_Innodb_row_lock_waits Number of times per second a row lock had to be waited for | InnoDB Row Lock Waits | Events / second |
mysql_Innodb_row_lock_time Rate of time spent in acquiring row locks for InnoDB tables | InnoDB Row Lock Time | milliseconds / second |
mysql_Innodb_buffer_pool_bytes_dirty Total current number of bytes held in dirty pages in the InnoDB buffer pool | InnoDB Buffer Pool Bytes Dirty | bytes |
mysql_Innodb_current_row_locks Number of current row locks | InnoDB Current Row Locks | Locks |
mysql_Innodb_buffer_pool_bytes_used Number of used bytes in the InnoDB Buffer Pool | InnoDB Buffer Pool Bytes Used | bytes |
mysql_Innodb_data_writes Rate of data writes | InnoDB Data Writes | Writes / second |
mysql_Innodb_Mutex_spin_rounds Rate of InnoDB semaphore/mutex spin rounds for the internal sync array | InnoDB Mutex Spin Rounds | Events / second |
mysql_Innodb_buffer_pool_bytes_total Total number of bytes in the InnoDB Buffer Pool | InnoDB Buffer Pool Bytes Total | bytes |
mysql_Innodb_os_log_fsyncs Rate of fsync writes to the log file | InnoDB OS Log Fsyncs Writes | Writes / second |
mysql_Innodb_row_lock_current_waits Number of row locks currently being waited for by operations on InnoDB tables | InnoDB Row Lock Current Waits | Locks |
mysql_Innodb_buffer_pool_bytes_free Number of free bytes in the InnoDB Buffer Pool | InnoDB Buffer Pool Bytes Free | bytes |
mysql_Innodb_data_reads Rate of data reads | InnoDB Data Reads | Reads / second |
mysql_Innodb_buffer_pool_utilization Utilization of the InnoDB Buffer Pool | InnoDB Buffer Pool Utilization | Fraction |
mysql_Innodb_buffer_pool_reads Number of logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk | InnoDB Buffer Pool Reads | Reads / second |
mysql_Innodb_Mutex_OS_waits Rate of InnoDB semaphore/mutex waits yielded to the OS. | InnoDB Mutex OS Waits | Events / second |
mysql_Binlog_disk_use Total binary log file size | BinLog Disk Use | bytes |
mysql_Binlog_cache_disk_use 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 | BinLog Cache Disk Use | Transactions |
mysql_performance_Handler_rollback Number of internal ROLLBACK statements | Performance Handler Rollback | Operations / second |
mysql_performance_Handler_delete Number of internal DELETE statements | Performance Handler Delete | Operations / second |
mysql_performance_Qcache_not_cached Number of noncached queries (not cacheable, or not cached due to the query_cache_type setting) | Performance Qcache Not Cached | Queries / second |
mysql_performance_Qcache_total_blocks Total number of blocks in the query cache | Performance Qcache Total Blocks | Blocks |
mysql_performance_Select_range Number of joins that used ranges on the first table. This is normally not a critical issue even if the value is quite large | Performance Select Range | Operations / second |
mysql_performance_Handler_read_prev Number of internal READ_PREV statements | Performance Handler Read Prev | Operations / second |
mysql_performance_Sort_rows Number of sorted rows | Performance Sort Rows | Operations / second |
mysql_performance_Qcache_free_memory Amount of free memory for the query cache | Performance Qcache Free Memory | bytes |
mysql_performance_Handler_read_rnd_next Number of internal READ_RND_NEXT statements | Performance Handler Read Rnd Next | Operations / second |
mysql_performance_Select_range_check 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 | Performance Select Range Check | Operations / second |
mysql_performance_Select_scan Number of joins that did a full scan of the first table | Performance Select Scan | Operations / second |
mysql_performance_Qcache_free_blocks Number of free memory blocks in the query cache | Performance Qcache Free Blocks | Blocks |
mysql_performance_Table_locks_immediate_rate Number of times a request for a table lock could be granted | Performance Table Locks Granted Immediate Rate | LocksGranted / second |
mysql_performance_Handler_prepare Number of internal PREPARE statements | Performance Handler Prepare | Operations / second |
mysql_performance_Opened_tables Number of tables opened. If Opened_tables is big, your table_open_cache value is probably too small | Performance Opened Tables | Tables / second |
mysql_performance_Handler_read_first Number of internal READ_FIRST statements | Performance Handler Read First | Operations / Second |
mysql_performance_Sort_merge_passes 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 | Performance Sort Merge Passes | Operations / second |
mysql_performance_Select_full_join Number of joins that do table scans because they do not use indexes. If this value is not 0, you should carefully check the indexes of your tables | Performance Select Full Join | Operations / second |
mysql_performance_Handler_read_key Number of internal READ_KEY statements | Performance Handler Read Key | Operations / second |
mysql_performance_Handler_read_next Number of internal READ_NEXT statements | Performance Handler Read Next | Operations / second |
mysql_performance_Threads_cached Number of threads in the thread cache | Performance Threads Cached | Threads |
mysql_performance_Table_locks_immediate Number of times a request for a table lock could be granted | Performance Table Locks Granted Immediate | LocksGranted / second |
mysql_performance_Threads_created Number of threads created to handle connections. If Threads_created is big, you may want to increase the thread_cache_size value | Performance Threads Created | Threads |
mysql_Binlog_cache_use Number of transactions that used the binary log cache | BinLog Cache Use | Transactions |
mysql_performance_Sort_range Number of sorts that were done using ranges | Performance Sort Range | Operations / second |
mysql_performance_Handler_read_rnd Number of internal READ_RND statements | Performance Handler Read Rnd | Operations / second |
mysql_performance_Handler_update Number of internal UPDATE statements | Performance Handler Update | Operations / second |
mysql_performance_Qcache_queries_in_cache Number of queries registered in the query cache | Performance Qcache Queries In Cache | Queries |
mysql_performance_Select_full_range_join Number of joins that used a range search on a reference table | Performance Select Full Range Join | Operations / second |
mysql_performance_Sort_scan Number of sorts that were done by scanning the table | Performance Sort Scan | Operations / second |
mysql_performance_Handler_write Number of internal WRITE statements | Performance Handler Write | Operations / second |
mysql_performance_Handler_commit Number of internal COMMIT statements | Performance Handler Commit | Operations / second |
mysql_performance_Table_open_cache_hits Number of hits for open tables cache lookups | Performance Table Open Cache Hits | Hits / second |
mysql_performance_Table_open_cache_misses Number of misses for open tables cache lookups | Performance Table Open Cache Misses | Misses / second |
mysql_Innodb_os_log_pending_fsyncs Number of pending InnoDB log fsync (sync-to-disk) requests | InnoDB OS Log Pending Fsyncs | Operations |
mysql_Innodb_s_lock_spin_waits Number of shared (read) semaphore spin waits within the InnoDB sync array | InnoDB S Lock Spin Waits | Waits / second |
mysql_Innodb_hash_index_cells_used Number of used cells of the adaptive hash index | InnoDB Hash Index Cells Used | Cells |
mysql_Innodb_pending_buffer_pool_flushes As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending Buffer Pool Flushes | Flushes |
mysql_Innodb_current_transactions Current InnoDB transactions | InnoDB Current Transactions | Transactions |
mysql_Innodb_queries_queued As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Queries Queued | Queries |
mysql_Innodb_tables_in_use InnoDB Tables In Use | InnoDB Tables In Use | Tables |
mysql_Innodb_pending_ibuf_aio_reads As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending Ibuf AIO Reads | Reads |
mysql_Innodb_pages_written Number of InnoDB pages written | InnoDB Pages Written | Pages / second |
mysql_Innodb_log_waits Number of times the log buffer was too small and a wait was required for it to be flushed before continuing | InnoDB Log Waits | Waits / second |
mysql_Innodb_buffer_pool_wait_free 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 | InnoDB Buffer Pool Wait Free | Waits |
mysql_Innodb_OS_file_fsyncs Rate of fsync() operations performed by InnoDB | InnoDB OS File Fsyncs | Operations / second |
mysql_Innodb_lsn_flushed Flushed up to log sequence number as shown in the LOG section of the SHOW ENGINE INNODB STATUS output | InnoDB Lsn Flushed | |
mysql_Innodb_ibuf_size Number of pages used within the InnoDB secondary index insert buffer | InnoDB Ibuf Size | Pages |
mysql_Innodb_buffer_pool_pages_data Number of pages in the InnoDB buffer pool with data. Number includes both dirty and clean pages | InnoDB Buffer Pool Pages Data | Pages |
mysql_Innodb_s_lock_spin_rounds Number of shared (read) semaphore spin rounds within the InnoDB sync array | InnoDB S Lock Spin Rounds | Rounds / second |
mysql_Innodb_rows_read Number of rows read from InnoDB tables | InnoDB Rows Read | Rows / second |
mysql_Innodb_lsn_current Current redo log sequence number within InnoDB | InnoSB Lsn Current | |
mysql_Innodb_x_lock_spin_rounds Number of exclusive (write) semaphore spin rounds within the InnoDB sync array | InnoDB X Lock Spin Rounds | Rounds / second |
mysql_Innodb_lsn_Last_checkpoint Log sequence number last checkpoint as shown in the LOG section of the SHOW ENGINE INNODB STATUS output | InnoDB Lsn Last Checkpoint | |
mysql_Innodb_os_log_pending_writes Number of pending InnoDB log writes | InnoDB OS Log Pending Writes | Writes |
mysql_Innodb_mem_recovery_system As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Recovery System | |
mysql_Innodb_s_lock_OS_waits Number of shared (read) semaphore waits yielded to the OS by InnoDB | InnodDB S Lock OS Waits | Waits / second |
mysql_Innodb_buffer_pool_pages_dirty Current number of dirty pages in the InnoDB buffer pool | InnoDB Buffer Pool Pages Dirty | Pages |
mysql_Innodb_mem_total Total memory allocated for the InnoDB buffer pool | InnoDB Mem Total | bytes |
mysql_Innodb_pending_aio_sync_ios As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending AIO Sync IOS | |
mysql_Innodb_ibuf_merged InnoDB Ibuf merged | InnoDB Ibuf Merged | Merges / second |
mysql_Innodb_queries_inside As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Queries Inside | Queries |
mysql_Innodb_mem_lock_system As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Lock System | |
mysql_Innodb_pending_log_writes Total number of writes pending to the InnoDB redo logs | InnoDB Pending Log Writes | Writes |
mysql_Innodb_Pages_created Number of InnoDB pages created | InnoDB Pages Created | Pages / second |
mysql_Innodb_buffer_pool_pages_free Number of free pages in the InnoDB buffer pool | InnoDB Buffer Pool Pages Free | Pages |
mysql_Innodb_Hash_index_cells_total Total number of cells of the adaptive hash index | InnoDB Hash Index Cells Total | Cells |
mysql_Innodb_ibuf_merged_inserts Rate of inserts to the InnoDB secondary index insert buffer | InnoDB Ibuf Merged Inserts | Operations / second |
mysql_Innodb_dblwr_pages_written Number of pages written per second to the doublewrite buffer | InnoDB Dblwr Pages Written | Pages / second |
mysql_Innodb_lock_structs Total number of lock structs in use by all transactions within InnoDB | InnoDB Lock Structs | Locks / second |
mysql_Innodb_rows_updated Number of rows updated in InnoDB tables | InnoDB Rows Updated | Rows / second |
mysql_Innodb_dblwr_writes Number of doublewrite operations performed per second | InnoDB Dblwr Writes | bytes / second |
mysql_Innodb_active_transactions InnoDB active transactions | InnoDB Active Transactions | Transactions |
mysql_Innodb_ibuf_merged_delete_marks Rate of deleted records merged by change buffering | InnoDB Ibuf Merged Delete Marks | Operations / second |
mysql_Innodb_data_read Amount of data read per second | InnoDB Data Read | bytes / second |
mysql_Innodb_buffer_pool_read_ahead_evicted Number of pages read into the InnoDB buffer pool by the read-ahead background thread that were subsequently evicted without being accessed by queries | InnoDB Buffer Pool Read Ahead Evicted | Pages / second |
mysql_Innodb_mem_additional_pool Total memory allocated for the InnoDB additional pool | InnoDB Mem Additional Pool | bytes |
mysql_Innodb_History_list_length Number of transactions that currently have undo space allocated to them (unpurged) | InnoDB History List Length | Transactions |
mysql_Innodb_data_pending_fsyncs Current number of pending fsync() operations | InnoDB Data Pending Fsyncs | Operations |
mysql_Innodb_OS_file_writes Rate of file writes performed by write threads within InnoDB | InnoDB OS File Writes | Writes / second |
mysql_Innodb_locked_transactions Total number of transactions waiting for row locks within InnoDB | InnoDB Locked Transactions | Transactions |
mysql_Innodb_Pending_normal_aio_writes As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending Normal AIO Writes | Writes |
mysql_Innodb_ibuf_merges InnoDB Ibuf merges | InnoDB Ibuf Merges | |
mysql_Innodb_mem_Adaptive_hash As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Adaptive Hash | bytes |
mysql_Innodb_mem_Page_hash As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Page Hash | |
mysql_Innodb_data_pending_reads Current number of pending reads | InnoDB Data Pending Reads | Reads |
mysql_Innodb_pending_checkpoint_writes Total number of currently pending checkpoint writes within InnoDB | InnoDB Pending Checkpoint Writes | Writes |
mysql_Innodb_Buffer_pool_pages_total Total size of the InnoDB buffer pool | InnoDB Buffer Pool Pages Total | Pages |
mysql_Innodb_data_written Amount of data written per second | InnoDB Data Written | bytes / second |
mysql_Innodb_buffer_pool_read_ahead Number of pages read into the InnoDB buffer pool by the read-ahead background thread | InnoDB Buffer Pool Read Ahead | Pages / second |
mysql_Innodb_semaphore_wait_time InnoDB semaphore wait time | InnoDB Semaphore Wait Time | seconds |
mysql_Innodb_buffer_pool_data Total number of bytes in the InnoDB buffer pool with data. The number includes both dirty and clean pages | InnoDB Buffer Pool Data | bytes |
mysql_Innodb_buffer_pool_read_ahead_rnd Number of random read-aheads initiated by InnoDB. This happens when a query scans a large part of a table but in random order | InnoDB Buffer Pool Read Ahead Rnd | Operations |
mysql_Innodb_semaphore_waits InnoDB semaphore waits | InnoDB Semaphore Waits | |
mysql_Innodb_log_writes Number of physical writes to the InnoDB redo log file | InnoDB Log Writes | Writes / second |
mysql_Innodb_OS_file_reads Rate of files reads performed by read threads within InnoDB | InnoDB OS File Reads | Reads / second |
mysql_Innodb_ibuf_merged_deletes Total number of times the InnoDB secondary index delete buffer was merged to the InnoDB datafiles | InnoDB Ibuf Merged Deletes | Operations / second |
mysql_Innodb_mem_thread_hash Checkpoint age as shown in the LOG section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Thread Hash | |
mysql_Innodb_log_write_requests Number of write requests for the InnoDB redo log | InnoDB Log Write Requests | Writes / second |
mysql_Innodb_mem_dictionary As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem Dictionary | bytes |
mysql_Innodb_Pending_normal_aio_reads As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending Normal AIO Reads | Reads |
mysql_Innodb_ibuf_free_list Insert buffer free list, as shown in the INSERT BUFFER AND ADAPTIVE HASH INDEX section of the SHOW ENGINE INNODB STATUS output | InnoDB Ibuf Free List | |
mysql_Innodb_x_lock_spin_waits Number of exclusive (write) semaphore spin waits within the InnoDB sync array | InnoDB X lock Spin Waits | Waits / second |
mysql_Innodb_os_log_written Number of bytes written to the InnoDB log | InnoDB OS Log Written | bytes / second |
mysql_Innodb_x_lock_OS_waits Number of exclusive (write) semaphore waits yielded to the OS by InnoDB | InnoDB X Lock OS Waits | Waits / second |
mysql_Innodb_pages_read Number of InnoDB pages read | InnoDB Pages Read | Pages / second |
mysql_Innodb_checkpoint_age Checkpoint age as shown in the LOG section of the SHOW ENGINE INNODB STATUS output | InnoDB Checkpoint Age | |
mysql_Innodb_buffer_pool_write_requests Number of writes done to the InnoDB buffer pool | InnoDB Buffer Pool Write Requests | Writes / second |
mysql_Innodb_buffer_pool_pages_flushed Number of requests to flush pages from the InnoDB buffer pool | InnoDB Buffer Pool Pages Flushed | Pages / second |
mysql_Innodb_Pending_log_flushes As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending Log Flushes | Flushes |
mysql_Innodb_rows_inserted Number of rows inserted into InnoDB tables | InnoDB Rows Inserted | Rows / second |
mysql_Innodb_ibuf_segment_size Total size, in pages, of the InnoDB secondary index insert buffer | InnoDB Ibuf Segment Size | Pages |
mysql_Innodb_rows_deleted Number of rows deleted from InnoDB tables | InnoDB Rows Deleted | Rows / second |
mysql_Innodb_read_views As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Read Views | |
mysql_Innodb_data_fsyncs Number of fsync() operations per second | InnoDB Data Fsyncs | Operations / second |
mysql_Innodb_data_pending_writes Current number of pending writes | InnoDB Data Pending Writes | Writes |
mysql_Innodb_mem_file_system As shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output | InnoDB Mem File System | |
mysql_Innodb_pending_aio_log_ios As shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output | InnoDB Pending AIO Log IOS | |
mysql_Innodb_locked_tables InnoDB tables locked | InnoDB Locked Tables | Tables |
mysql_galera_wsrep_flow_control_paused Shows the fraction of the time, since FLUSH STATUS was last called, that the node paused due to Flow Control | Galera Wsrep Flow Control Paused | Fraction |
mysql_galera_wsrep_cert_deps_distance Shows the average distance between the lowest and highest sequence number, or seqno, values that the node can possibly apply in parallel | Galera Wsrep Cert Deps Distance | |
mysql_galera_wsrep_local_recv_queue_avg Shows the average size of the local received queue since the last status query | Galera Wsrep Local Recv Queue Avg | |
mysql_galera_wsrep_cluster_size Current number of nodes in the Galera cluster | Galera Wsrep Cluster Size | Nodes |
mysql_galera_wsrep_local_send_queue_avg Show an average for the send queue length since the last FLUSH STATUS query | Galera Wsrep Local Send Queue Avg | |
mysql_performance_query_run_time_avg Avg query response time per schema | Performance Query Run Time Avg | microseconds |
mysql_performance_digest_95th_percentile_avg_us Query response time 95th percentile per schema | Performance Digest 95th Percentile Avg US | microseconds |
mysql_info_schema_size Size of schemas | Info Schema Size | megabytes |
mysql_replication_slaves_connected Number of slaves connected to a replication master | Replication Slaves Connected | Slaves |
mysql_replication_Seconds_Behind_Master Lag between the master and the slave | Replication Seconds Behind Master | seconds |
mysql_performance_Qcache_utilization_instant Percentage of the query cache memory being used at this instant (delta) | Performance Qcache Utilization Instant | percent |
mysql_performance_Qcache_utilization Percentage of the query cache memory currently being used | Performance Qcache Utilization | percent |
mysql_performance_Opened_files Number of files opened only with my_open() function | Performance Opened Files | Files |
mysql_performance_Open_table_definitions Number of cached .frm files. These files store the information of table structure in it | Performance Open Table Definitions | Files |
mysql_performance_Opened_table_definitions Number of .frm files cached. These files store the information of table structure in it | Performance Opened Table Definitions | Files |
mysql_performance_Com_call_procedure Number of call-procedure statements | Performance CallProcedure Statements | Queries / second |
mysql_performance_Handler_read_last Number of times the last entry in an index was read | Performance Handler Read Last | Reads / second |
mysql_Binlog_stmt_cache_disk_use Number of non-transaction statements that used the binary log statement cache but that exceeded the value of binlog_stmt_cache_size and used a temporary file to store those statements | BinLog Stmt Cache Disk Use | |
mysql_performance_Uptime Number of seconds that the server is up | Performance Uptime | seconds |
mysql_Innodb_io_capacity Limit on I/O activity for XtraDB/InnoDB background tasks, including merging data from the insert buffer and flushing pages. | InnoDB IO Capacity | |
mysql_Innodb_log_buffer_size Size of the buffer that InnoDB uses to write to the log files on disk. The default value is 1MB for the built-in InnoDB, 8MB for InnoDB Plugin. Sensible values range | InnoDB Log Buffer Size | bytes |
mysql_Innodb_flush_log_at_trx_commit Value of innodb_use_global_flush_log_at_trx_commit determines whether this variable can be reset with a SET statement or not | InnoDB Flush Log At Trx Commit | |
mysql_Innodb_force_recovery Crash recovery mode, the possible values are 0-6 : Normal Startup(0), Server Starts even if it detects a corrupt page(1), Prevent Master Thread from running(2), No Transaction Rollbacks after crash recovery(3), Prevent insert buffer merge Operations(4), Ignores undo logs-InnoDB treats incomplete Transactions as Committed(5), Ignores Redo log roll-forward in connection with recovery.(6) | InnoDB Force Recovery | Mode |
mysql_Innodb_log_file_size Size of each log file in a log group. The combined size of log files must be less than 4GB. The default value is 5MB. Sensible values range from 1MB to 1/N-th of the size of the buffer pool, where N is the number of log files in the group | InnoDB Log File Size | bytes |
mysql_Innodb_buffer_pool_size Size of the memory buffer InnoDB uses to cache data and indexes of its tables. The default value is 8MB. The larger you set this value, the less disk I/O is needed to access data in tables | InnoDB Buffer Pool Size | bytes |
mysql_Innodb_buffer_pool_pages_misc Number of pages that are busy because they are allocated for administrative overhead such as row locks or the adaptive hash index | InnoDB Buffer Pool Pages Misc | Pages |
mysql_Innodb_Buffer_Pool_hit_rate Buffer Pool hit rate | InnoDB Buffer Pool Hit Rate | Fraction |
mysql_Innodb_Hash_Searches Hash Searches | InnoDB Hash Searches | Searches |
mysql_Innodb_Non_Hash_Searches Non-Hash Searches | InnoDB NonHash Searches | Searches |