mysql - show global status(全局参数目录解说)

本文详细介绍了MySQL服务器的各种全局状态变量及其含义,包括连接管理、查询执行情况、表锁信息等,有助于理解MySQL运行时的状态及性能表现。

摘要生成于 C知道 ,由 DeepSeek-R1 满血版支持, 前往体验 >

[root@mysqldb ~]# mysql -uroot -e 'show global status' -p
show global status
show status
show session status
Variable_nameValueDescription
Aborted_clients0The number of connections that were aborted because the client died without closing the connection properly.
Aborted_connects1The number of failed attempts to connect to the MySQL server.
Binlog_cache_disk_use0使用临时二进制文件缓冲但查过binlog_cache_size大小以及使用一个临时文件去存储statements的事务数量
Binlog_cache_use0使用二进制日志缓存的事务数量
Binlog_stmt_cache_disk_use0使用二进制日志查询缓存(statement cache)以及超越binlog_stmt_cache_size以及使用一个临时文件区存储查询的非事务语句缓存数量
Binlog_stmt_cache_use0使用二进制日志缓存语句的非事务语句的数量
Bytes_received979从所有客户端中获取的字节数目
Bytes_sent20128从所有客户端中发送的字节数目
Com_admin_commands0com_xxx语句状态变量 是计数器 不能修改 表示每个xxx语句被执行的次数(QPS TPS就是com)
Com_assign_to_keycache0有一个状态参数给每种语句 记录指标
Com_alter_db0alter_db
Com_alter_db_upgrade0alter_db_upgrade
Com_alter_event0alter_event
Com_alter_function0alter_function
Com_alter_instance0
Com_alter_procedure0
Com_alter_server0
Com_alter_table0
Com_alter_tablespace0
Com_alter_user0
Com_analyze0
Com_begin0
Com_binlog0
Com_call_procedure0
Com_change_db0
Com_change_master0
Com_change_repl_filter0
Com_check0
Com_checksum0校验和
Com_commit0
Com_create_db0
Com_create_event0
Com_create_function0
Com_create_index0
Com_create_procedure0
Com_create_server0
Com_create_table0
Com_create_trigger0
Com_create_udf0
Com_create_user0
Com_create_view0
Com_dealloc_sql0
Com_delete0
Com_delete_multi0
Com_do0
Com_drop_db0
Com_drop_event0
Com_drop_function0
Com_drop_index0
Com_drop_procedure0
Com_drop_server0
Com_drop_table0
Com_drop_trigger0
Com_drop_user0
Com_drop_view0
Com_empty_query0
Com_execute_sql0
Com_explain_other0
Com_flush0
Com_get_diagnostics0
Com_grant0
Com_ha_close0
Com_ha_open0
Com_ha_read0
Com_help0
Com_insert0
Com_insert_select0
Com_install_plugin0
Com_kill0
Com_load0
Com_lock_tables0
Com_optimize0
Com_preload_keys0
Com_prepare_sql0
Com_purge0
Com_purge_before_date0
Com_release_savepoint0
Com_rename_table0
Com_rename_user0
Com_repair0
Com_replace0
Com_replace_select0
Com_reset0
Com_resignal0
Com_revoke0
Com_revoke_all0
Com_rollback0
Com_rollback_to_savepoint0
Com_savepoint0
Com_select5
Com_set_option0
Com_signal0
Com_show_binlog_events0
Com_show_binlogs0
Com_show_charsets0
Com_show_collations0
Com_show_create_db0
Com_show_create_event0
Com_show_create_func0
Com_show_create_proc0
Com_show_create_table0
Com_show_create_trigger0
Com_show_databases0
Com_show_engine_logs0
Com_show_engine_mutex0
Com_show_engine_status0
Com_show_events0
Com_show_errors0
Com_show_fields0
Com_show_function_code0
Com_show_function_status0
Com_show_grants0
Com_show_keys0
Com_show_master_status0
Com_show_open_tables0
Com_show_plugins0
Com_show_privileges0
Com_show_procedure_code0
Com_show_procedure_status0
Com_show_processlist0
Com_show_profile0
Com_show_profiles0
Com_show_relaylog_events0
Com_show_slave_hosts0
Com_show_slave_status0
Com_show_status2
Com_show_storage_engines0
Com_show_table_status0
Com_show_tables0
Com_show_triggers0
Com_show_variables2
Com_show_warnings0
Com_show_create_user0
Com_shutdown0
Com_slave_start0
Com_slave_stop0
Com_group_replication_start0
Com_group_replication_stop0
Com_stmt_execute0所有的com_stmt_xxx参数增加 一个准备好的语句参数未知或者
Com_stmt_close0发生一个错误在执行过程中 也就是说:这些值与请求的数量一致
Com_stmt_fetch0不是对成功完成的请求数量
Com_stmt_prepare0
Com_stmt_reset0
Com_stmt_send_long_data0
Com_truncate0
Com_uninstall_plugin0
Com_unlock_tables0
Com_update0
Com_update_multi0
Com_xa_commit0
Com_xa_end0
Com_xa_prepare0
Com_xa_recover0
Com_xa_rollback0
Com_xa_start0
Com_stmt_reprepare0
CompressionOFF是否客户连接使用压缩在客户端协议
Connection_errors_accept0在监听端口调用accept()函数的错误数量
Connection_errors_internal0因为server内部错误拒绝连接的数量
Connection_errors_max_connections0由于max_connections限制导致连接失败的数量
Connection_errors_peer_address0寻找连接客户端IP地址的时候报错
Connection_errors_select0在调用select()和poll()在监听端口发生错误数量
Connection_errors_tcpwrap0TCP wrappers 是透过客户端想要链接的程序文件名,然后分析客户端的 IP ,看看是否需要放行。 The number of connections refused by the libwrap library.
Connections7
Created_tmp_disk_tables10如果内部的临时表最初被创建作为一个内存(in-memory)表但变太大 mysql自动转化为磁盘表。内存表的最大尺寸是tmp_table_size和max_heap_table_size值的最小值。如果created_tmp_disk_tables太大,你想增加tmp_table_size或者max_heap_table_size值减轻类似的内存进内部临时表将被转化为磁盘表
Created_tmp_files5
Created_tmp_tables66
Delayed_errors0以INSERT DELAYED的行数目已经发生一些错误 状态参数不被赞成
Delayed_insert_threads0INSERT DELAYED 的数目处理线程使用非事务表
Delayed_writes0The number of INSERT DELAYED rows written to nontransactional tables.
Flush_commands1The number of times the server flushes tables, whether because a user executed a FLUSH TABLES statement or due to internal server operation. It is also incremented by receipt of a COM_REFRESH packet. This is in contrast to Com_flush, which indicates how many FLUSH statements have been executed, whether FLUSH TABLES, FLUSH LOGS, and so forth
Handler_commit16内部commit语句数目
Handler_delete0行被delete的次数
Handler_discover0
Handler_external_lock226The server increments this variable for each call to its external_lock() function, which generally occurs at the beginning and end of access to a table instance. There might be differences among storage engines. This variable can be used, for example, to discover for a statement that accesses a partitioned table how many partitions were pruned before locking occurred: Check how much the counter increased for the statement, subtract 2 (2 calls for the table itself), then divide by 2 to get the number of partitions locked.
Handler_mrr_init0The number of times the server uses a storage engine’s own Multi-Range Read implementation for table access.
Handler_prepare0A counter for the prepare phase of two-phase commit operations.
Handler_read_first13The number of times the first entry in an index was read. If this value is high, it suggests that the server is doing a lot of full index scans; for example, SELECT col1 FROM foo, assuming that col1 is indexed.
Handler_read_key11The number of requests to read a row based on a key. If this value is high, it is a good indication that your tables are properly indexed for your queries.
Handler_read_last0The number of requests to read the last key in an index. With ORDER BY, the server will issue a first-key request followed by several next-key requests, whereas with ORDER BY DESC, the server will issue a last-key request followed by several previous-key requests.
Handler_read_next2The number of requests to read the next row in key order. This value is incremented if you are querying an index column with a range constraint or if you are doing an index scan.
Handler_read_prev0The number of requests to read the previous row in key order. This read method is mainly used to optimize ORDER BY … DESC.
Handler_read_rnd0The number of requests to read a row based on a fixed position. This value is high if you are doing a lot of queries that require sorting of the result. You probably have a lot of queries that require MySQL to scan entire tables or you have joins that do not use keys properly.
Handler_read_rnd_next941The number of requests to read the next row in the data file. This value is high if you are doing a lot of table scans. Generally this suggests that your tables are not properly indexed or that your queries are not written to take advantage of the indexes you have.
Handler_rollback0The number of requests for a storage engine to perform a rollback operation.
Handler_savepoint0The number of requests for a storage engine to place a savepoint.
Handler_savepoint_rollback0The number of requests for a storage engine to roll back to a savepoint
Handler_update0The number of requests to update a row in a table
Handler_write907The number of requests to insert a row in a table
Innodb_buffer_pool_dump_statusDumping of buffer pool not startedThe progress of an operation to record the pages held in the InnoDB buffer pool, triggered by the setting of innodb_buffer_pool_dump_at_shutdown or innodb_buffer_pool_dump_now.
Innodb_buffer_pool_load_statusBuffer pool(s) load completed at 180831 11:44:06The progress of an operation to warm up the InnoDB buffer pool by reading in a set of pages corresponding to an earlier point in time, triggered by the setting of innodb_buffer_pool_load_at_startup or innodb_buffer_pool_load_now. If the operation introduces too much overhead, you can cancel it by setting innodb_buffer_pool_load_abort.
Innodb_buffer_pool_resize_status
Innodb_buffer_pool_pages_data274The number of pages in the InnoDB buffer pool containing data. The number includes both dirty and clean pages. When using compressed tables, the reported Innodb_buffer_pool_pages_data value may be larger than Innodb_buffer_pool_pages_total (Bug #59550).
Innodb_buffer_pool_bytes_data4489216The total number of bytes in the InnoDB buffer pool containing data. The number includes both dirty and clean pages. For more accurate memory usage calculations than with Innodb_buffer_pool_pages_data, when compressed tables cause the buffer pool to hold pages of different sizes.
Innodb_buffer_pool_pages_dirty0The current number of dirty pages in the InnoDB buffer pool
Innodb_buffer_pool_bytes_dirty0The total current number of bytes held in dirty pages in the InnoDB buffer pool. For more accurate memory usage calculations than with Innodb_buffer_pool_pages_dirty, when compressed tables cause the buffer pool to hold pages of different sizes.
Innodb_buffer_pool_pages_flushed39The number of requests to flush pages from the InnoDB buffer pool.
Innodb_buffer_pool_pages_free32490The number of pages free pages in the InnoDB buffer pool
Innodb_buffer_pool_pages_misc0The number of pages in the InnoDB buffer pool that are busy because they have been allocated for administrative overhead(开销), such as row locks or the adaptive hash index(自适应Hash索引). This value can also be calculated as Innodb_buffer_pool_pages_total − Innodb_buffer_pool_pages_free − Innodb_buffer_pool_pages_data. When using compressed tables(压缩表), Innodb_buffer_pool_pages_misc may report an out-of-bounds value (Bug #59550).
Innodb_buffer_pool_pages_total32764The total size of the InnoDB buffer pool, in pages. When using compressed tables, the reported Innodb_buffer_pool_pages_data value may be larger than Innodb_buffer_pool_pages_total (Bug #59550)
Innodb_buffer_pool_read_ahead_rnd0The number of “random” read-aheads initiated by InnoDB. This happens when a query scans a large portion of a table but in random order.
Innodb_buffer_pool_read_ahead0The number of pages read into the InnoDB buffer pool by the read-ahead background thread.
Innodb_buffer_pool_read_ahead_evicted0The number of pages read into the InnoDB buffer pool by the read-ahead background thread that were subsequently evicted(eviction The process of removing an item from a cache or other temporary storage area, such as the InnoDB buffer pool. Often, but not always, uses the LRU algorithm to determine which item to remove. When a dirty page is evicted, its contents are flushed to disk, and any dirty neighbor pages might be flushed also.) without having been accessed by queries.
Innodb_buffer_pool_read_requests1356The number of logical read requests.
Innodb_buffer_pool_reads240The number of logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk.(逻辑读的数量 InnoDB不能满足缓存池 直接从磁盘读取)
Innodb_buffer_pool_wait_free0Normally, writes to the InnoDB buffer pool happen in the background. 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. If innodb_buffer_pool_size has been set properly, this value should be small.
Innodb_buffer_pool_write_requests515The number of writes done to the InnoDB buffer pool
Innodb_data_fsyncs7The number of fsync() operations so far.The frenquency of fsync() calls is influenced by the setting of the innodb_flush_method configuration option
Innodb_data_pending_fsyncs0The current number of pending(待定) fsync() operations.The frequency of fsync() calls is influenced by the setting of the innodb_flush_method configuration option
Innodb_data_pending_reads0The current number of pending reads
Innodb_data_pending_writes0The current number of pending writes
Innodb_data_read4002304The amount of data read since the server was started(in bytes)
Innodb_data_reads271The total number of data reads(OS file reads)
Innodb_data_writes244The total number of data writes
Innodb_data_written674304The amount of data written so far,in bytes
Innodb_dblwr_pages_written2The number of pages that have been written to the doublewrite buffer.
Innodb_dblwr_writes1The number of doublewrite operations that have been performed
Innodb_log_waits0The number of times that log buffer was too small and a wait was required for it to be flushed before continuing.
Innodb_log_write_requests1The number of write requests for the InnoDB redo log
Innodb_log_writes2The number of physical writes to the InnoDB redo log file.
Innodb_os_log_fsyncs4The number of fsync() writes done to the InnoDB redo log files
Innodb_os_log_pending_fsyncs0The number of pending fsync() operations for the InnoDB redo log files
Innodb_os_log_pending_writes(未决写入)0The number of pending writes to the InnoDB redo log files.
Innodb_os_log_written1536The number of bytes written to the InnoDB redo log files
Innodb_page_size16384InnoDB page size(default 16K)Many values are counted in pages;the page size enables them to be easily converted to bytes.
Innodb_pages_created35The number of pages created by operations on InnoDB tables
Innodb_pages_read239The number of pages read from the InnoDB buffer pool by operations on InnoDB tables
Innodb_pages_written39The number of pages written by operations on InnoDB tables
Innodb_row_lock_current_waits0The number of row locks currently being waited for by operations on InnoDB tables.
Innodb_row_lock_time0The total time spent in acquiring row locks for InnoDB tables, in milliseconds.
Innodb_row_lock_time_avg0The average time to acquire a row lock for InnoDB tables, in milliseconds.
Innodb_row_lock_time_max0The maximum time to acquire a row lock for InnoDB tables, in milliseconds.
Innodb_row_lock_waits0The number of times operations on InnoDB tables had to wait for a row lock
Innodb_rows_deleted0The number of rows deleted from InnoDB tables
Innodb_rows_inserted0The number of rows inserted into InnoDB tables
Innodb_rows_read8The number of rows read from InnoDB tables
Innodb_rows_updated0The number of rows updated from InnoDB tables
Innodb_num_open_files23The number of files InnoDB currently holds open
Innodb_truncated_status_writes0The number of times output from the SHOW ENGINE InnoDB STATUS statement has been truncated
Innodb_available_undo_logs128The total number of available InnoDB rollback segments. Supplements the innodb_rollback_segments system variable, which defines the number of active rollback segments.
Key_blocks_not_flushed0The number of key blocks in the MyISAM key cache that have changed but have not yet been flushed to disk.
Key_blocks_unused26789The number of unused blocks in the MyISAM key cache. You can use this value to determine how much of the key cache is in use
Key_blocks_used3The number of used blocks in the MyISAM key cache. This value is a high-water mark that indicates the maximum number of blocks that have ever been in use at one time.
Key_read_requests6The number of requests to read a key block from the MyISAM key cache.
Key_reads3The number 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.
Key_write_requests0The number of requests to write a key block to the MyISAM key cache.
Key_writes0The number of physical writes of a key block from the MyISAM key cache to disk.
Last_query_cost0.000000The total cost of the last compiled query as computed by the query optimizer. This is useful for comparing the cost of different query plans for the same query. The default value of 0 means that no query has been compiled yet. The default value is 0. Last_query_cost has session scope.
Last_query_partial_plans0The Last_query_cost value can be computed accurately only for simple “flat” queries, not complex queries such as those with subqueries or UNION. For the latter, the value is set to 0.
Locked_connects0The number of iterations the query optimizer made in execution plan construction for the previous query. Last_query_cost has session scope.
Max_execution_time_exceeded0
Max_execution_time_set0
Max_execution_time_set_failed0
Max_used_connections1
Max_used_connections_time2018-08-31 11:47:38
Not_flushed_delayed_rows0The number of rows waiting to be written to nontransactional tables in INSERT DELAYED queues.-*This status variable is deprecated (because DELAYED inserts are deprecated), and will be removed in a future release.
Ongoing_anonymous_transaction_count0
Open_files15The number of files that have been opened with my_open() (a mysys library function). Parts of the server that open files without using this function do not increment the count.
Open_streams0The number of streams that are open (used mainly for logging).
Open_table_definitions219The number of cached .frm files.
Open_tables101The number of tables that are open
Opened_files349The number of files that have been opened with my_open() (a mysys library function). Parts of the server that open files without using this function do not increment the count.
Opened_table_definitions219The number of .frm files that have been cached.
Opened_tables108The number of tables that have been opened. If Opened_tables is big, your table_open_cache value is probably too small.
Performance_schema_accounts_lost0Performance Schema status variables are listed in Section 22.15, “Performance Schema Status Variables”. These variables provide information about instrumentation that could not be loaded or created due to memory constraints.
Performance_schema_cond_classes_lost0
Performance_schema_cond_instances_lost0
Performance_schema_digest_lost0
Performance_schema_file_classes_lost0
Performance_schema_file_handles_lost0
Performance_schema_file_instances_lost0
Performance_schema_hosts_lost0
Performance_schema_index_stat_lost0
Performance_schema_locker_lost0
Performance_schema_memory_classes_lost0
Performance_schema_metadata_lock_lost0
Performance_schema_mutex_classes_lost0
Performance_schema_mutex_instances_lost0
Performance_schema_nested_statement_lost0
Performance_schema_prepared_statements_lost0
Performance_schema_program_lost0
Performance_schema_rwlock_classes_lost0
Performance_schema_rwlock_instances_lost0
Performance_schema_session_connect_attrs_lost0
Performance_schema_socket_classes_lost0
Performance_schema_socket_instances_lost0
Performance_schema_stage_classes_lost0
Performance_schema_statement_classes_lost0
Performance_schema_table_handles_lost0
Performance_schema_table_instances_lost0
Performance_schema_table_lock_stat_lost0
Performance_schema_thread_classes_lost0
Performance_schema_thread_instances_lost0
Performance_schema_users_lost0
Prepared_stmt_count0The current number of prepared statements. (The maximum number of statements is given by the max_prepared_stmt_count system variable.)
Qcache_free_blocks1The number of free memory blocks in the query cache.
Qcache_free_memory1031832The amount of free memory for the query cache.
Qcache_hits0The number of query cache hits.
Qcache_inserts0The number of queries added to the query cache.
Qcache_lowmem_prunes0The number of queries that were deleted from the query cache because of low memory.
Qcache_not_cached4The number of noncached queries (not cacheable, or not cached due to the query_cache_type setting).
Qcache_queries_in_cache0The number of queries registered in the query cache.
Qcache_total_blocks1The total number of blocks in the query cache.
Queries12The number of statements executed by the server. This variable includes statements executed within stored programs, unlike the Questions variable. It does not count COM_PING or COM_STATISTICS commands.-*The discussion at the beginning of this section indicates how to relate this statement-counting status variable to other such variables.
Questions10The number of statements executed by the server. This includes only statements sent to the server by clients and not statements executed within stored programs, unlike the Queries variable. This variable does not count COM_PING, COM_STATISTICS, COM_STMT_PREPARE, COM_STMT_CLOSE, or COM_STMT_RESET commands.
Select_full_join0The 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.
Select_full_range_join0The number of joins that used a range search on a reference table.
Select_range0The number of joins that used ranges on the first table. This is normally not a critical issue even if the value is quite large.
Select_range_check0The 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.
Select_scan5The number of joins that did a full scan of the first table.
Slave_heartbeat_period0.000Shows the replication heartbeat interval (in seconds) on a replication slave.
Slave_last_heartbeatShows when the most recent heartbeat signal was received by a replication slave, as a TIMESTAMP value.
Slave_open_temp_tables0The number of temporary tables that the slave SQL thread currently has open. If the value is greater than zero, it is not safe to shut down the slave; see Section 17.4.1.30, “Replication and Temporary Tables”.
Slave_received_heartbeats0This counter increments with each replication heartbeat received by a replication slave since the last time that the slave was restarted or reset, or a CHANGE MASTER TO statement was issued.
Slave_retried_transactions0The total number of times since startup that the replication slave SQL thread has retried transactions.
Slave_runningOFFThis is ON if this server is a replication slave that is connected to a replication master, and both the I/O and SQL threads are running; otherwise, it is OFF.
Slow_launch_threads0The number of threads that have taken more than slow_launch_time seconds to create
Slow_queries0The number of queries that have taken more than long_query_time seconds. This counter increments regardless of whether the slow query log is enabled. For information about that log, see Section 5.4.5, “The Slow Query Log”.
Sort_merge_passes0The 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.
Sort_range0The number of sorts that were done using ranges.
Sort_rows0The number of sorted rows.
Sort_scan0The number of sorts that were done by scanning the table.
Ssl_accept_renegotiates0The number of negotiates needed to establish the connection.
Ssl_accepts0The number of accepted SSL connections.
Ssl_callback_cache_hits0The number of callback cache hits.
Ssl_cipherThe current encryption cipher (empty for unencrypted connections).
Ssl_cipher_listThe list of possible SSL ciphers (empty for non-SSL connections).
Ssl_client_connects0The number of SSL connection attempts to an SSL-enabled master.
Ssl_connect_renegotiates0The number of negotiates needed to establish the connection to an SSL-enabled master.
Ssl_ctx_verify_depth0The SSL context verification depth (how many certificates in the chain are tested).
Ssl_ctx_verify_mode0The SSL context verification mode
Ssl_default_timeout0The default SSL timeout.
Ssl_finished_accepts0The number of successful SSL connections to the server.
Ssl_finished_connects0The number of successful slave connections to an SSL-enabled master.
Ssl_server_not_afterThe last date for which the SSL certificate is valid.
Ssl_server_not_beforeThe first date for which the SSL certificate is valid.
Ssl_session_cache_hits0The number of SSL session cache hits.
Ssl_session_cache_misses0The number of SSL session cache misses.
Ssl_session_cache_modeNONEThe SSL session cache mode.
Ssl_session_cache_overflows0The number of SSL session cache overflows.
Ssl_session_cache_size0The SSL session cache size.
Ssl_session_cache_timeouts0The number of SSL session cache timeouts.
Ssl_sessions_reused0How many SSL connections were reused from the cache.
Ssl_used_session_cache_entries0How many SSL session cache entries were used.
Ssl_verify_depth0The verification depth for replication SSL connections.
Ssl_verify_mode0The verification mode used by the server for a connection that uses SSL. The value is a bitmask; bits are defined in the openssl/ssl.h header file:
Ssl_versionThe SSL protocol version of the connection; for example, TLSv1. If the connection is not encrypted, the value is empty
Table_locks_immediate98The number of times that a request for a table lock could be granted immediately.
Table_locks_waited0The number of times that a request for a table lock could not be granted immediately and a wait was needed. If this is high and you have performance problems, you should first optimize your queries, and then either split your table or tables or use replication.
Table_open_cache_hits5The number of hits for open tables cache lookups.
Table_open_cache_misses108The number of misses for open tables cache lookups.
Table_open_cache_overflows0The number of overflows for the open tables cache. This is the number of times, after a table is opened or closed, a cache instance has an unused entry and the size of the instance is larger than table_open_cache / table_open_cache_instances.
Tc_log_max_pages_used0For the memory-mapped implementation of the log that is used by mysqld when it acts as the transaction coordinator for recovery of internal XA transactions, this variable indicates the largest number of pages used for the log since the server started. If the product of Tc_log_max_pages_used and Tc_log_page_size is always significantly less than the log size, the size is larger than necessary and can be reduced. (The size is set by the –log-tc-size option. This variable is unused: It is unneeded for binary log-based recovery, and the memory-mapped recovery log method is not used unless the number of storage engines that are capable of two-phase commit and that support XA transactions is greater than one. (InnoDB is the only applicable engine.)
Tc_log_page_size0The page size used for the memory-mapped implementation of the XA recovery log. The default value is determined using getpagesize(). This variable is unused for the same reasons as described for Tc_log_max_pages_used.
Tc_log_page_waits0For the memory-mapped implementation of the recovery log, this variable increments each time the server was not able to commit a transaction and had to wait for a free page in the log. If this value is large, you might want to increase the log size (with the –log-tc-size option). For binary log-based recovery, this variable increments each time the binary log cannot be closed because there are two-phase commits in progress. (The close operation waits until all such transactions are finished.)
Threads_cached0The number of threads in the thread cache.
Threads_connected1The number of currently open connections.
Threads_created1The number of threads created to handle connections. If Threads_created is big, you may want to increase the thread_cache_size value. The cache miss rate can be calculated as Threads_created/Connections.
Threads_running1The number of threads that are not sleeping.
Uptime9269The number of seconds that the server has been up.
Uptime_since_flush_status9269The number of seconds since the most recent FLUSH STATUS statement.

链接官方文档

评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值