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

版权声明:zhiyu https://blog.csdn.net/ichglauben/article/details/82255697
[root@mysqldb ~]# mysql -uroot -e 'show global status' -p
show global status
show status
show session status
Variable_name Value Description
Aborted_clients 0 The number of connections that were aborted because the client died without closing the connection properly.
Aborted_connects 1 The number of failed attempts to connect to the MySQL server.
Binlog_cache_disk_use 0 使用临时二进制文件缓冲但查过binlog_cache_size大小以及使用一个临时文件去存储statements的事务数量
Binlog_cache_use 0 使用二进制日志缓存的事务数量
Binlog_stmt_cache_disk_use 0 使用二进制日志查询缓存(statement cache)以及超越binlog_stmt_cache_size以及使用一个临时文件区存储查询的非事务语句缓存数量
Binlog_stmt_cache_use 0 使用二进制日志缓存语句的非事务语句的数量
Bytes_received 979 从所有客户端中获取的字节数目
Bytes_sent 20128 从所有客户端中发送的字节数目
Com_admin_commands 0 com_xxx语句状态变量 是计数器 不能修改 表示每个xxx语句被执行的次数(QPS TPS就是com)
Com_assign_to_keycache 0 有一个状态参数给每种语句 记录指标
Com_alter_db 0 alter_db
Com_alter_db_upgrade 0 alter_db_upgrade
Com_alter_event 0 alter_event
Com_alter_function 0 alter_function
Com_alter_instance 0
Com_alter_procedure 0
Com_alter_server 0
Com_alter_table 0
Com_alter_tablespace 0
Com_alter_user 0
Com_analyze 0
Com_begin 0
Com_binlog 0
Com_call_procedure 0
Com_change_db 0
Com_change_master 0
Com_change_repl_filter 0
Com_check 0
Com_checksum 0 校验和
Com_commit 0
Com_create_db 0
Com_create_event 0
Com_create_function 0
Com_create_index 0
Com_create_procedure 0
Com_create_server 0
Com_create_table 0
Com_create_trigger 0
Com_create_udf 0
Com_create_user 0
Com_create_view 0
Com_dealloc_sql 0
Com_delete 0
Com_delete_multi 0
Com_do 0
Com_drop_db 0
Com_drop_event 0
Com_drop_function 0
Com_drop_index 0
Com_drop_procedure 0
Com_drop_server 0
Com_drop_table 0
Com_drop_trigger 0
Com_drop_user 0
Com_drop_view 0
Com_empty_query 0
Com_execute_sql 0
Com_explain_other 0
Com_flush 0
Com_get_diagnostics 0
Com_grant 0
Com_ha_close 0
Com_ha_open 0
Com_ha_read 0
Com_help 0
Com_insert 0
Com_insert_select 0
Com_install_plugin 0
Com_kill 0
Com_load 0
Com_lock_tables 0
Com_optimize 0
Com_preload_keys 0
Com_prepare_sql 0
Com_purge 0
Com_purge_before_date 0
Com_release_savepoint 0
Com_rename_table 0
Com_rename_user 0
Com_repair 0
Com_replace 0
Com_replace_select 0
Com_reset 0
Com_resignal 0
Com_revoke 0
Com_revoke_all 0
Com_rollback 0
Com_rollback_to_savepoint 0
Com_savepoint 0
Com_select 5
Com_set_option 0
Com_signal 0
Com_show_binlog_events 0
Com_show_binlogs 0
Com_show_charsets 0
Com_show_collations 0
Com_show_create_db 0
Com_show_create_event 0
Com_show_create_func 0
Com_show_create_proc 0
Com_show_create_table 0
Com_show_create_trigger 0
Com_show_databases 0
Com_show_engine_logs 0
Com_show_engine_mutex 0
Com_show_engine_status 0
Com_show_events 0
Com_show_errors 0
Com_show_fields 0
Com_show_function_code 0
Com_show_function_status 0
Com_show_grants 0
Com_show_keys 0
Com_show_master_status 0
Com_show_open_tables 0
Com_show_plugins 0
Com_show_privileges 0
Com_show_procedure_code 0
Com_show_procedure_status 0
Com_show_processlist 0
Com_show_profile 0
Com_show_profiles 0
Com_show_relaylog_events 0
Com_show_slave_hosts 0
Com_show_slave_status 0
Com_show_status 2
Com_show_storage_engines 0
Com_show_table_status 0
Com_show_tables 0
Com_show_triggers 0
Com_show_variables 2
Com_show_warnings 0
Com_show_create_user 0
Com_shutdown 0
Com_slave_start 0
Com_slave_stop 0
Com_group_replication_start 0
Com_group_replication_stop 0
Com_stmt_execute 0 所有的com_stmt_xxx参数增加 一个准备好的语句参数未知或者
Com_stmt_close 0 发生一个错误在执行过程中 也就是说:这些值与请求的数量一致
Com_stmt_fetch 0 不是对成功完成的请求数量
Com_stmt_prepare 0
Com_stmt_reset 0
Com_stmt_send_long_data 0
Com_truncate 0
Com_uninstall_plugin 0
Com_unlock_tables 0
Com_update 0
Com_update_multi 0
Com_xa_commit 0
Com_xa_end 0
Com_xa_prepare 0
Com_xa_recover 0
Com_xa_rollback 0
Com_xa_start 0
Com_stmt_reprepare 0
Compression OFF 是否客户连接使用压缩在客户端协议
Connection_errors_accept 0 在监听端口调用accept()函数的错误数量
Connection_errors_internal 0 因为server内部错误拒绝连接的数量
Connection_errors_max_connections 0 由于max_connections限制导致连接失败的数量
Connection_errors_peer_address 0 寻找连接客户端IP地址的时候报错
Connection_errors_select 0 在调用select()和poll()在监听端口发生错误数量
Connection_errors_tcpwrap 0 TCP wrappers 是透过客户端想要链接的程序文件名,然后分析客户端的 IP ,看看是否需要放行。 The number of connections refused by the libwrap library.
Connections 7
Created_tmp_disk_tables 10 如果内部的临时表最初被创建作为一个内存(in-memory)表但变太大 mysql自动转化为磁盘表。内存表的最大尺寸是tmp_table_size和max_heap_table_size值的最小值。如果created_tmp_disk_tables太大,你想增加tmp_table_size或者max_heap_table_size值减轻类似的内存进内部临时表将被转化为磁盘表
Created_tmp_files 5
Created_tmp_tables 66
Delayed_errors 0 以INSERT DELAYED的行数目已经发生一些错误 状态参数不被赞成
Delayed_insert_threads 0 INSERT DELAYED 的数目处理线程使用非事务表
Delayed_writes 0 The number of INSERT DELAYED rows written to nontransactional tables.
Flush_commands 1 The 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_commit 16 内部commit语句数目
Handler_delete 0 行被delete的次数
Handler_discover 0
Handler_external_lock 226 The 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_init 0 The number of times the server uses a storage engine’s own Multi-Range Read implementation for table access.
Handler_prepare 0 A counter for the prepare phase of two-phase commit operations.
Handler_read_first 13 The 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_key 11 The 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_last 0 The 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_next 2 The 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_prev 0 The number of requests to read the previous row in key order. This read method is mainly used to optimize ORDER BY … DESC.
Handler_read_rnd 0 The 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_next 941 The 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_rollback 0 The number of requests for a storage engine to perform a rollback operation.
Handler_savepoint 0 The number of requests for a storage engine to place a savepoint.
Handler_savepoint_rollback 0 The number of requests for a storage engine to roll back to a savepoint
Handler_update 0 The number of requests to update a row in a table
Handler_write 907 The number of requests to insert a row in a table
Innodb_buffer_pool_dump_status Dumping of buffer pool not started The 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_status Buffer pool(s) load completed at 180831 11:44:06 The 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_data 274 The 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_data 4489216 The 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_dirty 0 The current number of dirty pages in the InnoDB buffer pool
Innodb_buffer_pool_bytes_dirty 0 The 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_flushed 39 The number of requests to flush pages from the InnoDB buffer pool.
Innodb_buffer_pool_pages_free 32490 The number of pages free pages in the InnoDB buffer pool
Innodb_buffer_pool_pages_misc 0 The 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_total 32764 The 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_rnd 0 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.
Innodb_buffer_pool_read_ahead 0 The number of pages read into the InnoDB buffer pool by the read-ahead background thread.
Innodb_buffer_pool_read_ahead_evicted 0 The 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_requests 1356 The number of logical read requests.
Innodb_buffer_pool_reads 240 The 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_free 0 Normally, 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_requests 515 The number of writes done to the InnoDB buffer pool
Innodb_data_fsyncs 7 The 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_fsyncs 0 The 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_reads 0 The current number of pending reads
Innodb_data_pending_writes 0 The current number of pending writes
Innodb_data_read 4002304 The amount of data read since the server was started(in bytes)
Innodb_data_reads 271 The total number of data reads(OS file reads)
Innodb_data_writes 244 The total number of data writes
Innodb_data_written 674304 The amount of data written so far,in bytes
Innodb_dblwr_pages_written 2 The number of pages that have been written to the doublewrite buffer.
Innodb_dblwr_writes 1 The number of doublewrite operations that have been performed
Innodb_log_waits 0 The number of times that log buffer was too small and a wait was required for it to be flushed before continuing.
Innodb_log_write_requests 1 The number of write requests for the InnoDB redo log
Innodb_log_writes 2 The number of physical writes to the InnoDB redo log file.
Innodb_os_log_fsyncs 4 The number of fsync() writes done to the InnoDB redo log files
Innodb_os_log_pending_fsyncs 0 The number of pending fsync() operations for the InnoDB redo log files
Innodb_os_log_pending_writes(未决写入) 0 The number of pending writes to the InnoDB redo log files.
Innodb_os_log_written 1536 The number of bytes written to the InnoDB redo log files
Innodb_page_size 16384 InnoDB page size(default 16K)Many values are counted in pages;the page size enables them to be easily converted to bytes.
Innodb_pages_created 35 The number of pages created by operations on InnoDB tables
Innodb_pages_read 239 The number of pages read from the InnoDB buffer pool by operations on InnoDB tables
Innodb_pages_written 39 The number of pages written by operations on InnoDB tables
Innodb_row_lock_current_waits 0 The number of row locks currently being waited for by operations on InnoDB tables.
Innodb_row_lock_time 0 The total time spent in acquiring row locks for InnoDB tables, in milliseconds.
Innodb_row_lock_time_avg 0 The average time to acquire a row lock for InnoDB tables, in milliseconds.
Innodb_row_lock_time_max 0 The maximum time to acquire a row lock for InnoDB tables, in milliseconds.
Innodb_row_lock_waits 0 The number of times operations on InnoDB tables had to wait for a row lock
Innodb_rows_deleted 0 The number of rows deleted from InnoDB tables
Innodb_rows_inserted 0 The number of rows inserted into InnoDB tables
Innodb_rows_read 8 The number of rows read from InnoDB tables
Innodb_rows_updated 0 The number of rows updated from InnoDB tables
Innodb_num_open_files 23 The number of files InnoDB currently holds open
Innodb_truncated_status_writes 0 The number of times output from the SHOW ENGINE InnoDB STATUS statement has been truncated
Innodb_available_undo_logs 128 The 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_flushed 0 The number of key blocks in the MyISAM key cache that have changed but have not yet been flushed to disk.
Key_blocks_unused 26789 The 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_used 3 The 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_requests 6 The number of requests to read a key block from the MyISAM key cache.
Key_reads 3 The 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_requests 0 The number of requests to write a key block to the MyISAM key cache.
Key_writes 0 The number of physical writes of a key block from the MyISAM key cache to disk.
Last_query_cost 0.000000 The 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_plans 0 The 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_connects 0 The number of iterations the query optimizer made in execution plan construction for the previous query. Last_query_cost has session scope.
Max_execution_time_exceeded 0
Max_execution_time_set 0
Max_execution_time_set_failed 0
Max_used_connections 1
Max_used_connections_time 2018-08-31 11:47:38
Not_flushed_delayed_rows 0 The 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_count 0
Open_files 15 The 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_streams 0 The number of streams that are open (used mainly for logging).
Open_table_definitions 219 The number of cached .frm files.
Open_tables 101 The number of tables that are open
Opened_files 349 The 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_definitions 219 The number of .frm files that have been cached.
Opened_tables 108 The number of tables that have been opened. If Opened_tables is big, your table_open_cache value is probably too small.
Performance_schema_accounts_lost 0 Performance 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_lost 0
Performance_schema_cond_instances_lost 0
Performance_schema_digest_lost 0
Performance_schema_file_classes_lost 0
Performance_schema_file_handles_lost 0
Performance_schema_file_instances_lost 0
Performance_schema_hosts_lost 0
Performance_schema_index_stat_lost 0
Performance_schema_locker_lost 0
Performance_schema_memory_classes_lost 0
Performance_schema_metadata_lock_lost 0
Performance_schema_mutex_classes_lost 0
Performance_schema_mutex_instances_lost 0
Performance_schema_nested_statement_lost 0
Performance_schema_prepared_statements_lost 0
Performance_schema_program_lost 0
Performance_schema_rwlock_classes_lost 0
Performance_schema_rwlock_instances_lost 0
Performance_schema_session_connect_attrs_lost 0
Performance_schema_socket_classes_lost 0
Performance_schema_socket_instances_lost 0
Performance_schema_stage_classes_lost 0
Performance_schema_statement_classes_lost 0
Performance_schema_table_handles_lost 0
Performance_schema_table_instances_lost 0
Performance_schema_table_lock_stat_lost 0
Performance_schema_thread_classes_lost 0
Performance_schema_thread_instances_lost 0
Performance_schema_users_lost 0
Prepared_stmt_count 0 The current number of prepared statements. (The maximum number of statements is given by the max_prepared_stmt_count system variable.)
Qcache_free_blocks 1 The number of free memory blocks in the query cache.
Qcache_free_memory 1031832 The amount of free memory for the query cache.
Qcache_hits 0 The number of query cache hits.
Qcache_inserts 0 The number of queries added to the query cache.
Qcache_lowmem_prunes 0 The number of queries that were deleted from the query cache because of low memory.
Qcache_not_cached 4 The number of noncached queries (not cacheable, or not cached due to the query_cache_type setting).
Qcache_queries_in_cache 0 The number of queries registered in the query cache.
Qcache_total_blocks 1 The total number of blocks in the query cache.
Queries 12 The 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.
Questions 10 The 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_join 0 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.
Select_full_range_join 0 The number of joins that used a range search on a reference table.
Select_range 0 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.
Select_range_check 0 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.
Select_scan 5 The number of joins that did a full scan of the first table.
Slave_heartbeat_period 0.000 Shows the replication heartbeat interval (in seconds) on a replication slave.
Slave_last_heartbeat Shows when the most recent heartbeat signal was received by a replication slave, as a TIMESTAMP value.
Slave_open_temp_tables 0 The 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_heartbeats 0 This 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_transactions 0 The total number of times since startup that the replication slave SQL thread has retried transactions.
Slave_running OFF This 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_threads 0 The number of threads that have taken more than slow_launch_time seconds to create
Slow_queries 0 The 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_passes 0 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.
Sort_range 0 The number of sorts that were done using ranges.
Sort_rows 0 The number of sorted rows.
Sort_scan 0 The number of sorts that were done by scanning the table.
Ssl_accept_renegotiates 0 The number of negotiates needed to establish the connection.
Ssl_accepts 0 The number of accepted SSL connections.
Ssl_callback_cache_hits 0 The number of callback cache hits.
Ssl_cipher The current encryption cipher (empty for unencrypted connections).
Ssl_cipher_list The list of possible SSL ciphers (empty for non-SSL connections).
Ssl_client_connects 0 The number of SSL connection attempts to an SSL-enabled master.
Ssl_connect_renegotiates 0 The number of negotiates needed to establish the connection to an SSL-enabled master.
Ssl_ctx_verify_depth 0 The SSL context verification depth (how many certificates in the chain are tested).
Ssl_ctx_verify_mode 0 The SSL context verification mode
Ssl_default_timeout 0 The default SSL timeout.
Ssl_finished_accepts 0 The number of successful SSL connections to the server.
Ssl_finished_connects 0 The number of successful slave connections to an SSL-enabled master.
Ssl_server_not_after The last date for which the SSL certificate is valid.
Ssl_server_not_before The first date for which the SSL certificate is valid.
Ssl_session_cache_hits 0 The number of SSL session cache hits.
Ssl_session_cache_misses 0 The number of SSL session cache misses.
Ssl_session_cache_mode NONE The SSL session cache mode.
Ssl_session_cache_overflows 0 The number of SSL session cache overflows.
Ssl_session_cache_size 0 The SSL session cache size.
Ssl_session_cache_timeouts 0 The number of SSL session cache timeouts.
Ssl_sessions_reused 0 How many SSL connections were reused from the cache.
Ssl_used_session_cache_entries 0 How many SSL session cache entries were used.
Ssl_verify_depth 0 The verification depth for replication SSL connections.
Ssl_verify_mode 0 The 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_version The SSL protocol version of the connection; for example, TLSv1. If the connection is not encrypted, the value is empty
Table_locks_immediate 98 The number of times that a request for a table lock could be granted immediately.
Table_locks_waited 0 The 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_hits 5 The number of hits for open tables cache lookups.
Table_open_cache_misses 108 The number of misses for open tables cache lookups.
Table_open_cache_overflows 0 The 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_used 0 For 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_size 0 The 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_waits 0 For 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_cached 0 The number of threads in the thread cache.
Threads_connected 1 The number of currently open connections.
Threads_created 1 The 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_running 1 The number of threads that are not sleeping.
Uptime 9269 The number of seconds that the server has been up.
Uptime_since_flush_status 9269 The number of seconds since the most recent FLUSH STATUS statement.

链接官方文档

猜你喜欢

转载自blog.csdn.net/ichglauben/article/details/82255697