MySQL is an open source relational database management system (RDBMS) based on Structured Query Language (SQL).

Prerequisites

  1. Create a user.
CREATE USER '<Username>'@'localhost' IDENTIFIED BY '<Password>';
  1. 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;

Note: @‘localhost’ is only for local connections. Use hostname/IP for remote connections.

  1. Use the username and password to monitor MySQL.

  2. 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.

Metrics

OpsRamp MetricMetric Display NameUnitDescription
mysql_performance_Qcache_insertsPerformance Qcache InsertsQueries / secondNumber of queries added to the query cache
mysql_performance_Table_locks_waitedPerformance Table Locks WaitedWaitTotal number of times a request for a table lock could not be granted immediately and a wait was needed
mysql_myisam_Key_buffer_bytes_usedMyISAM Key Buffer Bytes UsedbytesMyISAM key buffer bytes used
mysql_performance_Open_tablesPerformance Open TablesTablesNumber of tables that are open.
mysql_net_Max_used_connectionsNet Max Used ConnectionsConnectionsMaximum number of connections that have been in use simultaneously since the server started
mysql_performance_Com_delete_multiPerformance DeleteMulti StatementsQueries / secondRate of delete-multi statements
mysql_performance_Slow_queriesPerformance Slow QueriesQueries / secondRate of queries that have taken more than long_query_time
mysql_myisam_Key_buffer_bytes_unflushedMyISAM Key Buffer Bytes UnflushedbytesMyISAM key buffer bytes unflushed
mysql_performance_Bytes_sentPerformance Bytes Sentbytes / secondNumber of bytes sent to all clients
mysql_performance_Com_replacePerformance Replace StatementsQueries / secondRate of replace statements
mysql_performance_Com_deletePerformance Delete StatementsQueries / secondRate of delete statements
mysql_performance_Table_locks_waited_ratePerformance Table Locks Waited RateWaits / secondTotal number of times a request for a table lock could not be granted immediately and a wait was needed
mysql_performance_Threads_runningPerformance Threads RunningThreadsNumber of threads that are not sleeping
mysql_performance_QueriesPerformance QueriesQueries / secondRate of queries
mysql_net_Aborted_connectsNet Aborted ConnectsConnections / secondNumber of failed attempts to connect to the MySQL server
mysql_performance_Com_loadPerformance Load StatementsQueries / secondRate of load statements
mysql_performance_Qcache_lowmem_prunesPerformance Qcache LowMem PrunesQueries / secondNumber of queries that were deleted from the query cache because of low memory
mysql_performance_Created_tmp_tablesPerformance Created Tmp TablesTables / secondRate of internal temporary tables created by second by the server while executing statements
mysql_performance_Created_tmp_disk_tablesPerformance Created Tmp Disk TablesTables / secondRate of internal on-disk temporary tables created by second by the server while executing statements
mysql_myisam_Key_readsMyISAM Key ReadsReads / secondNumber of physical reads of a key block from disk into the MyISAM key cache. If Key_reads is large, then your key_buffer_size value is probably too small. The cache miss rate can be calculated as Key_reads/Key_read_requests.
mysql_performance_Com_replace_selectPerformance ReplaceSelect StatementsQueries / secondRate of replace-select statements
mysql_performance_Com_selectPerformance Select StatementsQueries / secondRate of select statements
mysql_performance_Bytes_receivedPerformance Bytes Receivedbytes / secondNumber of bytes received from all clients
mysql_myisam_Key_write_requestsMyISAM Key Write RequestsWrites / secondNumber of requests to write a key block to the MyISAM key cache
mysql_myisam_Key_writesMyISAM Key WritesWrites / secondNumber of physical writes of a key block from the MyISAM key cache to disk
mysql_performance_Com_insertPerformance Insert StatementsQueries / secondRate of insert statements
mysql_performance_Threads_connectedPerformance Threads ConnectedConnectionsNumber of currently open connections
mysql_performance_Com_update_multiPerformance UpdateMulti StatementsQueries / secondRate of update-multi statement
mysql_performance_Com_updatePerformance Update StatementsQueries / secondRate of update statements
mysql_net_ConnectionsNet ConnectionsConnections / secondRate of connections to the server
mysql_performance_Com_insert_selectPerformance InsertSelect StatementsQueries / secondRate of insert-select statements
mysql_performance_Qcache_hitsPerformance Qcache HitsHits / secondRate of query cache hits
mysql_performance_QuestionsPerformance QuestionsQueries / secondRate of statements executed by the server
mysql_performance_Created_tmp_filesPerformance Created Tmp FilesFiles / secondRate of temporary files created by second
mysql_myisam_Key_read_requestsMyISAM Key Read RequestsReads / secondNumber of requests to read a key block from the MyISAM key cache
mysql_performance_Open_filesPerformance Open FilesFilesNumber of open files
mysql_net_Aborted_clientsNet Aborted ClientsConnections / secondNumber of connections that were aborted because the client died without closing the connection properly
mysql_performance_query_cache_sizePerformance Query Cache SizebytesAmount of memory allocated for caching query results
mysql_performance_table_open_cachePerformance Table Open CacheTablesNumber of open tables for all threads. Increasing this value increases the number of file descriptors that mysqld requires
mysql_performance_Key_cache_utilizationPerformance Key Cache UtilizationFractionKey cache utilization ratio
mysql_performance_thread_cache_sizePerformance Thread Cache SizebytesHow 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
mysql_myisam_key_buffer_sizeMyISAM Key Buffer SizebytesSize of the buffer used for index blocks
mysql_net_max_connectionsNet Max ConnectionsConnectionsMaximum permitted number of simultaneous client connections
mysql_Innodb_buffer_pool_read_requestsInnoDB Buffer Pool Read RequestsReads / secondNumber of logical read requests
mysql_Innodb_Mutex_spin_waitsInnoDB Mutex Spin WaitsEvents / secondRate of InnoDB semaphore/mutex spin waits for the internal sync array
mysql_Innodb_row_lock_waitsInnoDB Row Lock WaitsEvents / secondNumber of times per second a row lock had to be waited for
mysql_Innodb_row_lock_timeInnoDB Row Lock Timemilliseconds / secondRate of time spent in acquiring row locks for InnoDB tables
mysql_Innodb_buffer_pool_bytes_dirtyInnoDB Buffer Pool Bytes DirtybytesTotal current number of bytes held in dirty pages in the InnoDB buffer pool
mysql_Innodb_current_row_locksInnoDB Current Row LocksLocksNumber of current row locks
mysql_Innodb_buffer_pool_bytes_usedInnoDB Buffer Pool Bytes UsedbytesNumber of used bytes in the InnoDB Buffer Pool
mysql_Innodb_data_writesInnoDB Data WritesWrites / secondRate of data writes
mysql_Innodb_Mutex_spin_roundsInnoDB Mutex Spin RoundsEvents / secondRate of InnoDB semaphore/mutex spin rounds for the internal sync array
mysql_Innodb_buffer_pool_bytes_totalInnoDB Buffer Pool Bytes TotalbytesTotal number of bytes in the InnoDB Buffer Pool
mysql_Innodb_os_log_fsyncsInnoDB OS Log Fsyncs WritesWrites / secondRate of fsync writes to the log file
mysql_Innodb_row_lock_current_waitsInnoDB Row Lock Current WaitsLocksNumber of row locks currently being waited for by operations on InnoDB tables
mysql_Innodb_buffer_pool_bytes_freeInnoDB Buffer Pool Bytes FreebytesNumber of free bytes in the InnoDB Buffer Pool
mysql_Innodb_data_readsInnoDB Data ReadsReads / secondRate of data reads
mysql_Innodb_buffer_pool_utilizationInnoDB Buffer Pool UtilizationFractionUtilization of the InnoDB Buffer Pool
mysql_Innodb_buffer_pool_readsInnoDB Buffer Pool ReadsReads / secondNumber of logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk
mysql_Innodb_Mutex_OS_waitsInnoDB Mutex OS WaitsEvents / secondRate of InnoDB semaphore/mutex waits yielded to the OS.
mysql_Binlog_disk_useBinLog Disk UsebytesTotal binary log file size
mysql_Binlog_cache_disk_useBinLog Cache Disk UseTransactionsNumber 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
mysql_performance_Handler_rollbackPerformance Handler RollbackOperations / secondNumber of internal ROLLBACK statements
mysql_performance_Handler_deletePerformance Handler DeleteOperations / secondNumber of internal DELETE statements
mysql_performance_Qcache_not_cachedPerformance Qcache Not CachedQueries / secondNumber of noncached queries (not cacheable, or not cached due to the query_cache_type setting)
mysql_performance_Qcache_total_blocksPerformance Qcache Total BlocksBlocksTotal number of blocks in the query cache
mysql_performance_Select_rangePerformance Select RangeOperations / secondNumber of joins that used ranges on the first table. This is normally not a critical issue even if the value is quite large
mysql_performance_Handler_read_prevPerformance Handler Read PrevOperations / secondNumber of internal READ_PREV statements
mysql_performance_Sort_rowsPerformance Sort RowsOperations / secondNumber of sorted rows
mysql_performance_Qcache_free_memoryPerformance Qcache Free MemorybytesAmount of free memory for the query cache
mysql_performance_Handler_read_rnd_nextPerformance Handler Read Rnd NextOperations / secondNumber of internal READ_RND_NEXT statements
mysql_performance_Select_range_checkPerformance Select Range CheckOperations / secondNumber 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
mysql_performance_Select_scanPerformance Select ScanOperations / secondNumber of joins that did a full scan of the first table
mysql_performance_Qcache_free_blocksPerformance Qcache Free BlocksBlocksNumber of free memory blocks in the query cache
mysql_performance_Table_locks_immediate_ratePerformance Table Locks Granted Immediate RateLocksGranted / secondNumber of times a request for a table lock could be granted immediately
mysql_performance_Handler_preparePerformance Handler PrepareOperations / secondNumber of internal PREPARE statements
mysql_performance_Opened_tablesPerformance Opened TablesTables / secondNumber of tables that have been opened. If Opened_tables is big, your table_open_cache value is probably too small
mysql_performance_Handler_read_firstPerformance Handler Read FirstOperations / SecondNumber of internal READ_FIRST statements
mysql_performance_Sort_merge_passesPerformance Sort Merge PassesOperations / secondNumber 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
mysql_performance_Select_full_joinPerformance Select Full JoinOperations / secondNumber 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
mysql_performance_Handler_read_keyPerformance Handler Read KeyOperations / secondNumber of internal READ_KEY statements
mysql_performance_Handler_read_nextPerformance Handler Read NextOperations / secondNumber of internal READ_NEXT statements
mysql_performance_Threads_cachedPerformance Threads CachedThreadsNumber of threads in the thread cache
mysql_performance_Table_locks_immediatePerformance Table Locks Granted ImmediateLocksGranted / secondNumber of times a request for a table lock could be granted immediately
mysql_performance_Threads_createdPerformance Threads CreatedThreadsNumber of threads created to handle connections. If Threads_created is big, you may want to increase the thread_cache_size value
mysql_Binlog_cache_useBinLog Cache UseTransactionsNumber of transactions that used the binary log cache
mysql_performance_Sort_rangePerformance Sort RangeOperations / secondNumber of sorts that were done using ranges
mysql_performance_Handler_read_rndPerformance Handler Read RndOperations / secondNumber of internal READ_RND statements
mysql_performance_Handler_updatePerformance Handler UpdateOperations / secondNumber of internal UPDATE statements
mysql_performance_Qcache_queries_in_cachePerformance Qcache Queries In CacheQueriesNumber of queries registered in the query cache
mysql_performance_Select_full_range_joinPerformance Select Full Range JoinOperations / secondNumber of joins that used a range search on a reference table
mysql_performance_Sort_scanPerformance Sort ScanOperations / secondNumber of sorts that were done by scanning the table
mysql_performance_Handler_writePerformance Handler WriteOperations / secondNumber of internal WRITE statements
mysql_performance_Handler_commitPerformance Handler CommitOperations / secondNumber of internal COMMIT statements
mysql_performance_Table_open_cache_hitsPerformance Table Open Cache HitsHits / secondNumber of hits for open tables cache lookups
mysql_performance_Table_open_cache_missesPerformance Table Open Cache MissesMisses / secondNumber of misses for open tables cache lookups
mysql_Innodb_os_log_pending_fsyncsInnoDB OS Log Pending FsyncsOperationsNumber of pending InnoDB log fsync (sync-to-disk) requests
mysql_Innodb_s_lock_spin_waitsInnoDB S Lock Spin WaitsWaits / secondNumber of shared (read) semaphore spin waits within the InnoDB sync array
mysql_Innodb_hash_index_cells_usedInnoDB Hash Index Cells UsedCellsNumber of used cells of the adaptive hash index
mysql_Innodb_pending_buffer_pool_flushesInnoDB Pending Buffer Pool FlushesFlushesAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_current_transactionsInnoDB Current TransactionsTransactionsCurrent InnoDB transactions
mysql_Innodb_queries_queuedInnoDB Queries QueuedQueriesAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_tables_in_useInnoDB Tables In UseTablesInnoDB Tables In Use
mysql_Innodb_pending_ibuf_aio_readsInnoDB Pending Ibuf AIO ReadsReadsAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_pages_writtenInnoDB Pages WrittenPages / secondNumber of InnoDB pages written
mysql_Innodb_log_waitsInnoDB Log WaitsWaits / secondNumber of times the log buffer was too small and a wait was required for it to be flushed before continuing
mysql_Innodb_buffer_pool_wait_freeInnoDB Buffer Pool Wait FreeWaitsWhen 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
mysql_Innodb_OS_file_fsyncsInnoDB OS File FsyncsOperations / secondRate of fsync() operations performed by InnoDB
mysql_Innodb_lsn_flushedInnoDB Lsn FlushedFlushed up to log sequence number as shown in the LOG section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_ibuf_sizeInnoDB Ibuf SizePagesNumber of pages used within the InnoDB secondary index insert buffer
mysql_Innodb_buffer_pool_pages_dataInnoDB Buffer Pool Pages DataPagesNumber of pages in the InnoDB buffer pool containing data. Number includes both dirty and clean pages
mysql_Innodb_s_lock_spin_roundsInnoDB S Lock Spin RoundsRounds / secondNumber of shared (read) semaphore spin rounds within the InnoDB sync array
mysql_Innodb_rows_readInnoDB Rows ReadRows / secondNumber of rows read from InnoDB tables
mysql_Innodb_lsn_currentInnoSB Lsn CurrentCurrent redo log sequence number within InnoDB
mysql_Innodb_x_lock_spin_roundsInnoDB X Lock Spin RoundsRounds / secondNumber of exclusive (write) semaphore spin rounds within the InnoDB sync array
mysql_Innodb_lsn_Last_checkpointInnoDB Lsn Last CheckpointLog sequence number last checkpoint as shown in the LOG section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_os_log_pending_writesInnoDB OS Log Pending WritesWritesNumber of pending InnoDB log writes
mysql_Innodb_mem_recovery_systemInnoDB Mem Recovery SystemAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_s_lock_OS_waitsInnodDB S Lock OS WaitsWaits / secondNumber of shared (read) semaphore waits yielded to the OS by InnoDB
mysql_Innodb_buffer_pool_pages_dirtyInnoDB Buffer Pool Pages DirtyPagesCurrent number of dirty pages in the InnoDB buffer pool
mysql_Innodb_mem_totalInnoDB Mem TotalbytesTotal memory allocated for the InnoDB buffer pool
mysql_Innodb_pending_aio_sync_iosInnoDB Pending AIO Sync IOSAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_ibuf_mergedInnoDB Ibuf MergedMerges / secondInnoDB Ibuf merged
mysql_Innodb_queries_insideInnoDB Queries InsideQueriesAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_mem_lock_systemInnoDB Mem Lock SystemAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_pending_log_writesInnoDB Pending Log WritesWritesTotal number of writes pending to the InnoDB redo logs
mysql_Innodb_Pages_createdInnoDB Pages CreatedPages / secondNumber of InnoDB pages created
mysql_Innodb_buffer_pool_pages_freeInnoDB Buffer Pool Pages FreePagesNumber of free pages in the InnoDB buffer pool
mysql_Innodb_Hash_index_cells_totalInnoDB Hash Index Cells TotalCellsTotal number of cells of the adaptive hash index
mysql_Innodb_ibuf_merged_insertsInnoDB Ibuf Merged InsertsOperations / secondRate of inserts to the InnoDB secondary index insert buffer
mysql_Innodb_dblwr_pages_writtenInnoDB Dblwr Pages WrittenPages / secondNumber of pages written per second to the doublewrite buffer
mysql_Innodb_lock_structsInnoDB Lock StructsLocks / secondTotal number of lock structs in use by all transactions within InnoDB
mysql_Innodb_rows_updatedInnoDB Rows UpdatedRows / secondNumber of rows updated in InnoDB tables
mysql_Innodb_dblwr_writesInnoDB Dblwr Writesbytes / secondNumber of doublewrite operations performed per second
mysql_Innodb_active_transactionsInnoDB Active TransactionsTransactionsInnoDB active transactions
mysql_Innodb_ibuf_merged_delete_marksInnoDB Ibuf Merged Delete MarksOperations / secondRate of deleted records merged by change buffering
mysql_Innodb_data_readInnoDB Data Readbytes / secondAmount of data read per second
mysql_Innodb_buffer_pool_read_ahead_evictedInnoDB Buffer Pool Read Ahead EvictedPages / secondNumber of pages read into the InnoDB buffer pool by the read-ahead background thread that were subsequently evicted without having been accessed by queries
mysql_Innodb_mem_additional_poolInnoDB Mem Additional PoolbytesTotal memory allocated for the InnoDB additional pool
mysql_Innodb_History_list_lengthInnoDB History List LengthTransactionsNumber of transactions that currently have undo space allocated to them (unpurged)
mysql_Innodb_data_pending_fsyncsInnoDB Data Pending FsyncsOperationsCurrent number of pending fsync() operations
mysql_Innodb_OS_file_writesInnoDB OS File WritesWrites / secondRate of file writes performed by write threads within InnoDB
mysql_Innodb_locked_transactionsInnoDB Locked TransactionsTransactionsTotal number of transactions waiting for row locks within InnoDB
mysql_Innodb_Pending_normal_aio_writesInnoDB Pending Normal AIO WritesWritesAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_ibuf_mergesInnoDB Ibuf MergesInnoDB Ibuf merges
mysql_Innodb_mem_Adaptive_hashInnoDB Mem Adaptive HashbytesAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_mem_Page_hashInnoDB Mem Page HashAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_data_pending_readsInnoDB Data Pending ReadsReadsCurrent number of pending reads
mysql_Innodb_pending_checkpoint_writesInnoDB Pending Checkpoint WritesWritesTotal number of currently pending checkpoint writes within InnoDB
mysql_Innodb_Buffer_pool_pages_totalInnoDB Buffer Pool Pages TotalPagesTotal size of the InnoDB buffer pool
mysql_Innodb_data_writtenInnoDB Data Writtenbytes / secondAmount of data written per second
mysql_Innodb_buffer_pool_read_aheadInnoDB Buffer Pool Read AheadPages / secondNumber of pages read into the InnoDB buffer pool by the read-ahead background thread
mysql_Innodb_semaphore_wait_timeInnoDB Semaphore Wait TimesecondsInnoDB semaphore wait time
mysql_Innodb_buffer_pool_dataInnoDB Buffer Pool DatabytesTotal number of bytes in the InnoDB buffer pool containing data. The number includes both dirty and clean pages
mysql_Innodb_buffer_pool_read_ahead_rndInnoDB Buffer Pool Read Ahead RndOperationsNumber of random read-aheads initiated by InnoDB. This happens when a query scans a large portion of a table but in random order
mysql_Innodb_semaphore_waitsInnoDB Semaphore WaitsInnoDB semaphore waits
mysql_Innodb_log_writesInnoDB Log WritesWrites / secondNumber of physical writes to the InnoDB redo log file
mysql_Innodb_OS_file_readsInnoDB OS File ReadsReads / secondRate of files reads performed by read threads within InnoDB
mysql_Innodb_ibuf_merged_deletesInnoDB Ibuf Merged DeletesOperations / secondTotal number of times the InnoDB secondary index delete buffer was merged to the InnoDB datafiles
mysql_Innodb_mem_thread_hashInnoDB Mem Thread HashCheckpoint age as shown in the LOG section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_log_write_requestsInnoDB Log Write RequestsWrites / secondNumber of write requests for the InnoDB redo log
mysql_Innodb_mem_dictionaryInnoDB Mem DictionarybytesAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_Pending_normal_aio_readsInnoDB Pending Normal AIO ReadsReadsAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_ibuf_free_listInnoDB Ibuf Free ListInsert buffer free list, as shown in the INSERT BUFFER AND ADAPTIVE HASH INDEX section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_x_lock_spin_waitsInnoDB X lock Spin WaitsWaits / secondNumber of exclusive (write) semaphore spin waits within the InnoDB sync array
mysql_Innodb_os_log_writtenInnoDB OS Log Writtenbytes / secondNumber of bytes written to the InnoDB log
mysql_Innodb_x_lock_OS_waitsInnoDB X Lock OS WaitsWaits / secondNumber of exclusive (write) semaphore waits yielded to the OS by InnoDB
mysql_Innodb_pages_readInnoDB Pages ReadPages / secondNumber of InnoDB pages read
mysql_Innodb_checkpoint_ageInnoDB Checkpoint AgeCheckpoint age as shown in the LOG section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_buffer_pool_write_requestsInnoDB Buffer Pool Write RequestsWrites / secondNumber of writes done to the InnoDB buffer pool
mysql_Innodb_buffer_pool_pages_flushedInnoDB Buffer Pool Pages FlushedPages / secondNumber of requests to flush pages from the InnoDB buffer pool
mysql_Innodb_Pending_log_flushesInnoDB Pending Log FlushesFlushesAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_rows_insertedInnoDB Rows InsertedRows / secondNumber of rows inserted into InnoDB tables
mysql_Innodb_ibuf_segment_sizeInnoDB Ibuf Segment SizePagesTotal size, in pages, of the InnoDB secondary index insert buffer
mysql_Innodb_rows_deletedInnoDB Rows DeletedRows / secondNumber of rows deleted from InnoDB tables
mysql_Innodb_read_viewsInnoDB Read ViewsAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_data_fsyncsInnoDB Data FsyncsOperations / secondNumber of fsync() operations per second
mysql_Innodb_data_pending_writesInnoDB Data Pending WritesWritesCurrent number of pending writes
mysql_Innodb_mem_file_systemInnoDB Mem File SystemAs shown in the BUFFER POOL AND MEMORY section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_pending_aio_log_iosInnoDB Pending AIO Log IOSAs shown in the FILE I/O section of the SHOW ENGINE INNODB STATUS output
mysql_Innodb_locked_tablesInnoDB Locked TablesTablesInnoDB tables locked
mysql_galera_wsrep_flow_control_pausedGalera Wsrep Flow Control PausedFractionShows the fraction of the time, since FLUSH STATUS was last called, that the node paused due to Flow Control
mysql_galera_wsrep_cert_deps_distanceGalera Wsrep Cert Deps DistanceShows the average distance between the lowest and highest sequence number, or seqno, values that the node can possibly apply in parallel
mysql_galera_wsrep_local_recv_queue_avgGalera Wsrep Local Recv Queue AvgShows the average size of the local received queue since the last status query
mysql_galera_wsrep_cluster_sizeGalera Wsrep Cluster SizeNodesCurrent number of nodes in the Galera cluster
mysql_galera_wsrep_local_send_queue_avgGalera Wsrep Local Send Queue AvgShow an average for the send queue length since the last FLUSH STATUS query
mysql_performance_query_run_time_avgPerformance Query Run Time AvgmicrosecondsAvg query response time per schema
mysql_performance_digest_95th_percentile_avg_usPerformance Digest 95th Percentile Avg USmicrosecondsQuery response time 95th percentile per schema
mysql_info_schema_sizeInfo Schema SizemegabytesSize of schemas
mysql_replication_slaves_connectedReplication Slaves ConnectedSlavesNumber of slaves connected to a replication master
mysql_replication_Seconds_Behind_MasterReplication Seconds Behind MastersecondsLag between the master and the slave
mysql_performance_Qcache_utilization_instantPerformance Qcache Utilization InstantpercentPercentage of the query cache memory being used at this instant (delta)
mysql_performance_Qcache_utilizationPerformance Qcache UtilizationpercentPercentage of the query cache memory currently being used
mysql_performance_Opened_filesPerformance Opened FilesFilesNumber of files that have been opened only with my_open() function
mysql_performance_Open_table_definitionsPerformance Open Table DefinitionsFilesNumber of cached .frm files. These files store the information of table structure in it
mysql_performance_Opened_table_definitionsPerformance Opened Table DefinitionsFilesNumber of .frm files that have been cached. These files store the information of table structure in it
mysql_performance_Com_call_procedurePerformance CallProcedure StatementsQueries / secondNumber of call-procedure statements
mysql_performance_Handler_read_lastPerformance Handler Read LastReads / secondNumber of times the last entry in an index was read
mysql_Binlog_stmt_cache_disk_useBinLog Stmt Cache Disk UseNumber 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
mysql_performance_UptimePerformance UptimesecondsNumber of seconds that the server has been up
mysql_Innodb_io_capacityInnoDB IO CapacityLimit on I/O activity for XtraDB/InnoDB background tasks, including merging data from the insert buffer and flushing pages.
mysql_Innodb_log_buffer_sizeInnoDB Log Buffer SizebytesSize 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
mysql_Innodb_flush_log_at_trx_commitInnoDB Flush Log At Trx CommitValue of innodb_use_global_flush_log_at_trx_commit determines whether this variable can be reset with a SET statement or not
mysql_Innodb_force_recoveryInnoDB Force RecoveryModeCrash 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)
mysql_Innodb_log_file_sizeInnoDB Log File SizebytesSize 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
mysql_Innodb_buffer_pool_sizeInnoDB Buffer Pool SizebytesSize 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
mysql_Innodb_buffer_pool_pages_miscInnoDB Buffer Pool Pages MiscPagesNumber of pages that are busy because they have been allocated for administrative overhead such as row locks or the adaptive hash index
mysql_Innodb_Buffer_Pool_hit_rateInnoDB Buffer Pool Hit RateFractionBuffer Pool hit rate
mysql_Innodb_Hash_SearchesInnoDB Hash SearchesSearchesHash Searches
mysql_Innodb_Non_Hash_SearchesInnoDB NonHash SearchesSearchesNon-Hash Searches