您的当前位置:首页正文

(转)mysqlShowglobalstatus参数详解

2021-10-31 来源:V品旅游网
(转)mysqlShowglobalstatus参数详解

Show global status

在Show global status输出中的项。 5.1⼿册中没有的或者翻译有问题的,都附带5.5原⽂说明:

Aborted_clients

由于客户端没有正确关闭连接导致客户端终⽌⽽中断的连接数。

Aborted_connects

试图连接到MySQL服务器⽽失败的连接数。

Binlog_cache_disk_use

使⽤临时⼆进制⽇志缓存但超过binlog_cache_size值并使⽤临时⽂件来保存事务中的语句的事务数量。

Binlog_cache_use

使⽤临时⼆进制⽇志缓存的事务数量。

Binlog_stmt_cache_disk_use

The number of nontransaction statements that used the binary log statement cache but that exceeded the value of binlog_stmt_cache_sizeand used a temporary file to store those statements.

当⾮事务语句使⽤⼆进制⽇志缓存,但是超出binlog_stmt_cache_size时,使⽤⼀个临时⽂件来存放这些语句。

Binlog_stmt_cache_use

The number of nontransactional statements that used the binary log statement cache.使⽤⼆进制⽇志缓存⽂件的⾮事务语句数量。

Bytes_received

从所有客户端接收到的字节数。

Bytes_sent

发送给所有客户端的字节数。

Com_admin_commands [ Com_xxx ]

Com_xxx 语句计数变量表⽰每个xxx 语句执⾏的次数。每类语句有⼀个状态变量。例如,Com_delete和Com_insert分别统计DELETE 和INSERT语句执⾏的次数。Com_xxx包括:Com_alter_db

Com_alter_db_upgradeCom_alter_eventCom_alter_functionCom_alter_procedureCom_alter_serverCom_alter_tableCom_alter_tablespaceCom_analyze

Com_assign_to_keycache

Com_beginCom_binlogCom_call_procedureCom_change_dbCom_change_masterCom_checkCom_checksumCom_commitCom_create_dbCom_create_eventCom_create_functionCom_create_indexCom_create_procedureCom_create_serverCom_create_tableCom_create_triggerCom_create_udfCom_create_userCom_create_viewCom_dealloc_sqlCom_deleteCom_delete_multiCom_doCom_drop_dbCom_drop_eventCom_drop_functionCom_drop_indexCom_drop_procedureCom_drop_serverCom_drop_tableCom_drop_triggerCom_drop_userCom_drop_viewCom_empty_queryCom_execute_sqlCom_flushCom_grantCom_ha_closeCom_ha_open

Com_ha_readCom_helpCom_insertCom_insert_selectCom_install_pluginCom_killCom_loadCom_lock_tablesCom_optimizeCom_preload_keysCom_prepare_sqlCom_purge

Com_purge_before_dateCom_release_savepointCom_rename_tableCom_rename_userCom_repairCom_replaceCom_replace_selectCom_resetCom_resignalCom_revokeCom_revoke_allCom_rollback

Com_rollback_to_savepointCom_savepointCom_selectCom_set_optionCom_show_authorsCom_show_binlog_eventsCom_show_binlogsCom_show_charsetsCom_show_collationsCom_show_contributorsCom_show_create_dbCom_show_create_eventCom_show_create_funcCom_show_create_procCom_show_create_table

Com_show_create_triggerCom_show_databasesCom_show_engine_logsCom_show_engine_mutexCom_show_engine_statusCom_show_errorsCom_show_eventsCom_show_fieldsCom_show_function_codeCom_show_function_statusCom_show_grantsCom_show_keysCom_show_logs

Com_show_master_statusCom_show_new_masterCom_show_open_tablesCom_show_pluginsCom_show_privilegesCom_show_procedure_codeCom_show_procedure_statusCom_show_processlistCom_show_profileCom_show_profilesCom_show_relaylog_eventsCom_show_slave_hostsCom_show_slave_statusCom_show_status

Com_show_storage_enginesCom_show_table_statusCom_show_tablesCom_show_triggersCom_show_variablesCom_show_warningsCom_signalCom_slave_startCom_slave_stopCom_stmt_closeCom_stmt_executeCom_stmt_fetch

Com_stmt_prepareCom_stmt_reprepareCom_stmt_reset

Com_stmt_send_long_dataCom_truncateCom_uninstall_pluginCom_unlock_tablesCom_updateCom_update_multiCom_xa_commitCom_xa_endCom_xa_prepareCom_xa_recoverCom_xa_rollbackCom_xa_start

Compression

客户端是否使⽤了压缩的连接协议。

Connections

试图连接到(不管是否成功)MySQL服务器的连接数。

Created_tmp_disk_tables

服务器执⾏语句时在硬盘上⾃动创建的临时表的数量。

Created_tmp_files

mysqld已经创建的临时⽂件的数量。

Created_tmp_tables

服务器执⾏语句时⾃动创建的内存中的临时表的数量。如果Created_tmp_disk_tables较⼤,你可能要增加tmp_table_size值使临时表基于内存⽽不基于硬盘。

Delayed_errors

⽤INSERT DELAYED写的出现错误的⾏数(可能为duplicate key)。

Delayed_insert_threads

使⽤的INSERT DELAYED处理器线程数。

Delayed_writes

写⼊的INSERT DELAYED⾏数。

Flush_commands

执⾏的FLUSH语句数。

Handler_commit

内部提交语句数。

Handler_delete

⾏从表中删除的次数。

Handler_discover

MySQL服务器可以问NDB CLUSTER存储引擎是否知道某⼀名字的表。这被称作发现。Handler_discover说明通过该⽅法发现的次数。

Handler_prepare

准备阶段的两阶段提交操作计数器。

Handler_read_first

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; forexample, SELECT col1 FROM foo, assuming that col1 is indexed.

索引中第⼀条被读的次数。如果较⾼,它表明服务器正执⾏⼤量全索引扫描;例如,SELECT col1 FROM foo,假定col1有索引。

Handler_read_key

根据键读⼀⾏的请求数。如果较⾼,说明查询和表的索引正确。

Handler_read_last

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 With ORDER BY DESC, the server will issue a last-key request followed by several previous-key requests.This variable was added in MySQL 5.5.7.

查询读最后⼀个索引的请求数。当使⽤ORDER BY时,服务器优先发出使⽤第⼀个索引的请求,之后是使⽤其他索引。当使⽤ORDER BYDESC时,服务器优先发出使⽤最后⼀个索引的请求, 之后是前⼏个索引的请求。

Handler_read_next

按照键顺序读下⼀⾏的请求数。如果你⽤范围约束或如果执⾏索引扫描来查询索引列,该值增加。

Handler_read_prev

按照键顺序读前⼀⾏的请求数。该读⽅法主要⽤于优化ORDER BY ... DESC

Handler_read_rnd

根据固定位置读⼀⾏的请求数。如果你正执⾏⼤量查询并需要对结果进⾏排序该值较⾼。你可能使⽤了⼤量需要MySQL扫描整个表的查询或你的连接没有正确使⽤键。

Handler_read_rnd_next

在数据⽂件中读下⼀⾏的请求数。如果你正进⾏⼤量的表扫描,该值较⾼。通常说明你的表索引不正确或写⼊的查询没有利⽤索引。

Handler_rollback

内部ROLLBACK语句的数量。

Handler_savepoint

The number of requests for a storage engine to place a savepoint.存储引擎放置⼀个保存点的请求数。

Handler_savepoint_rollback

The number of requests for a storage engine to roll back to a savepoint.存储引擎回滚到⼀个保存点的请求。

Handler_update

在表内更新⼀⾏的请求数

Handler_write

在表内插⼊⼀⾏的请求数。

Innodb_buffer_pool_pages_data

包含数据的页数(脏或⼲净)。

Innodb_buffer_pool_pages_dirty

当前的脏页数。

Innodb_buffer_pool_pages_flushed

要求清空的缓冲池页数。

Innodb_buffer_pool_pages_free

空页数。

Innodb_buffer_pool_pages_latched

在InnoDB缓冲池中锁定的页数。这是当前正读或写或由于其它原因不能清空或删除的页数。

Innodb_buffer_pool_pages_misc

忙的页数,因为它们已经被分配优先⽤作管理,例如⾏锁定或适⽤的哈希索引。该值还可以计算为Innodb_buffer_pool_pages_total -Innodb_buffer_pool_pages_free - Innodb_buffer_pool_pages_data。

Innodb_buffer_pool_pages_total

缓冲池总⼤⼩(页数)。

Innodb_buffer_pool_read_ahead

The number of pages read into the InnoDB buffer pool by the read-ahead background thread.后台预读线程读取到Innodb缓冲池的页的数量。

Innodb_buffer_pool_read_ahead_evicted

The number of pages read into the InnoDB buffer pool by the read-ahead background thread that were subsequently evicted without havingbeen accessed by queries.

后台预读线程读取到Innodb缓冲池的页由于未被查询使⽤⽽驱逐的数量。

Innodb_buffer_pool_read_requests

InnoDB已经完成的逻辑读请求数。

Innodb_buffer_pool_reads

不能满⾜InnoDB必须单页读取的缓冲池中的逻辑读数量。

Innodb_buffer_pool_wait_free

⼀般情况,通过后台向InnoDB缓冲池写。但是,如果需要读或创建页,并且没有⼲净的页可⽤,则它还需要先等待页⾯清空。该计数器对等待实例进⾏记数。如果已经适当设置缓冲池⼤⼩,该值应⼩。

Innodb_buffer_pool_write_requests

向InnoDB缓冲池的写数量。

Innodb_data_fsyncs

fsync()操作数。

Innodb_data_pending_fsyncs

当前挂起的fsync()操作数。

Innodb_data_pending_reads

当前挂起的读数。

Innodb_data_pending_writes

当前挂起的写数。

Innodb_data_read

⾄此已经读取的数据数量(字节)

Innodb_data_reads

数据读总数量。

Innodb_data_writes

数据写总数量。

Innodb_data_written

⾄此已经写⼊的数据量(字节)。

Innodb_dblwr_pages_written

The number of pages that have been written for doublewrite operations.双写操作执⾏的页的数量。

Innodb_dblwr_writes

The number of doublewrite operations that have been performed.已经执⾏的双写操作的数量。

Innodb_have_atomic_builtins

Indicates whether the server was built with atomic instructions.指⽰服务器是否建⽴原⼦操作指令。

Innodb_log_waits

我们必须等待的时间,因为⽇志缓冲区太⼩,我们在继续前必须先等待对它清空。

Innodb_log_write_requests

⽇志写请求数。

Innodb_log_writes

向⽇志⽂件的物理写数量。

Innodb_os_log_fsyncs

向⽇志⽂件完成的fsync()写数量

Innodb_os_log_pending_fsyncs

挂起的⽇志⽂件fsync()操作数量。

Innodb_os_log_pending_writes

挂起的⽇志⽂件写操作。

Innodb_os_log_written

写⼊⽇志⽂件的字节数。

Innodb_page_size

编译的InnoDB页⼤⼩(默认16KB)。许多值⽤页来记数;页的⼤⼩很容易转换为字节。

Innodb_pages_created

创建的页数。

Innodb_pages_read

读取的页数。

Innodb_pages_written

写⼊的页数。

Innodb_row_lock_current_waits

当前等待的待锁定的⾏数。

Innodb_row_lock_time

⾏锁定花费的总时间,单位毫秒。

Innodb_row_lock_time_avg

⾏锁定的平均时间,单位毫秒。

Innodb_row_lock_time_max

⾏锁定的最长时间,单位毫秒。

Innodb_row_lock_waits

⼀⾏锁定必须等待的时间数。

Innodb_rows_deleted

从InnoDB表删除的⾏数。

Innodb_rows_inserted

插⼊到InnoDB表的⾏数。

Innodb_rows_read

从InnoDB表读取的⾏数。

Innodb_rows_updated

InnoDB表内更新的⾏数。

Innodb_truncated_status_writes

The number of times output from the SHOW ENGINE INNODB STATUS is truncated. Monitoring applications that parse the output fromthis command can test this value before and after issuing the SHOW ENGINE command, to confirm if the output is complete or not.SHOW ENGINE INNODB STATUS 的输出时间将被截断。监控程序解析这个输出,可以测试这项之前和之后的值,以确认输出是否完整。

Key_blocks_not_flushed

键缓存内已经更改但还没有清空到硬盘上的键的数据块数量。

Key_blocks_unused

键缓存内未使⽤的块数量。你可以使⽤该值来确定使⽤了多少键缓存;

Key_blocks_used

键缓存内使⽤的块数量。该值为⾼⽔平线标记,说明已经同时最多使⽤了多少块。

Key_read_requests

从缓存读键的数据块的请求数。

Key_reads

从硬盘读取键的数据块的次数。如果Key_reads较⼤,则Key_buffer_size值可能太⼩。可以⽤Key_reads/Key_read_requests计算缓存损失率。

Key_write_requests

将键的数据块写⼊缓存的请求数。

Key_writes

向硬盘写⼊将键的数据块的物理写操作的次数。

Last_query_cost

⽤查询优化器计算的最后编译的查询的总成本。⽤于对⽐同⼀查询的不同查询⽅案的成本。默认值0表⽰还没有编译查询。默认值是0。Last_query_cost具有会话范围。

Max_used_connections

服务器启动后已经同时使⽤的连接的最⼤数量。

MySQL Cluster Status Variables

Ndb_api_bytes_received_countNdb_api_bytes_received_count_sessionNdb_api_bytes_received_count_slaveNdb_api_bytes_sent_countNdb_api_bytes_sent_count_sessionNdb_api_bytes_sent_count_slaveNdb_api_event_bytes_countNdb_api_event_bytes_count_injectorNdb_api_event_data_countNdb_api_event_data_count_injectorNdb_api_event_nondata_countNdb_api_event_nondata_count_injectorNdb_api_pk_op_countNdb_api_pk_op_count_sessionNdb_api_pk_op_count_slaveNdb_api_pruned_scan_countNdb_api_pruned_scan_count_sessionNdb_api_pruned_scan_count_slaveNdb_api_range_scan_countNdb_api_range_scan_count_sessionNdb_api_range_scan_count_slaveNdb_api_read_row_countNdb_api_read_row_count_sessionNdb_api_read_row_count_slave

Ndb_api_scan_batch_countNdb_api_scan_batch_count_sessionNdb_api_scan_batch_count_slaveNdb_api_table_scan_countNdb_api_table_scan_count_sessionNdb_api_table_scan_count_slaveNdb_api_trans_abort_countNdb_api_trans_abort_count_sessionNdb_api_trans_abort_count_slaveNdb_api_trans_close_countNdb_api_trans_close_count_sessionNdb_api_trans_close_count_slaveNdb_api_trans_commit_countNdb_api_trans_commit_count_sessionNdb_api_trans_commit_count_slaveNdb_api_trans_local_read_row_countNdb_api_trans_local_read_row_count_sessionNdb_api_trans_local_read_row_count_slaveNdb_api_trans_start_countNdb_api_trans_start_count_sessionNdb_api_trans_start_count_slaveNdb_api_uk_op_countNdb_api_uk_op_count_sessionNdb_api_uk_op_count_slaveNdb_api_wait_exec_complete_countNdb_api_wait_exec_complete_count_sessionNdb_api_wait_exec_complete_count_slaveNdb_api_wait_meta_request_countNdb_api_wait_meta_request_count_sessionNdb_api_wait_meta_request_count_slaveNdb_api_wait_nanos_countNdb_api_wait_nanos_count_sessionNdb_api_wait_nanos_count_slaveNdb_api_wait_scan_result_countNdb_api_wait_scan_result_count_sessionNdb_api_wait_scan_result_count_slavendb_cluster_connection_poolNdb_cluster_node_idNdb_config_from_host

Ndb_conflict_fn_epochNdb_conflict_fn_epoch_transNdb_conflict_fn_maxNdb_conflict_fn_old

Ndb_conflict_trans_conflict_commit_countNdb_conflict_trans_detect_iter_countNdb_conflict_trans_reject_countNdb_conflict_trans_row_conflict_countNdb_conflict_trans_row_reject_countndb_execute_countndb-nodeid

Ndb_number_of_data_nodesndb_pruned_scan_countNdb_pushed_queries_definedNdb_pushed_queries_droppedNdb_pushed_queries_executedndb_pushed_readsndb_scan_count

Not_flushed_delayed_rows

等待写⼊INSERT DELAY队列的⾏数。

Open_files

打开的⽂件的数⽬。

Open_streams

打开的流的数量(主要⽤于记录)。

Open_table_definitions

The number of cached .frm files.被缓存的.FRM⽂件数量

Open_tables

当前打开的表的数量。

Opened_files

已经打开的表的数量。如果Opened_tables较⼤,table_cache 值可能太⼩。

Opened_table_definitions

The number of .frm files that have been cached.被缓存过的.FRM⽂件的数量。

Opened_tables

已经打开的表的数量。如果Opened_tables较⼤,table_cache 值可能太⼩。

Performance Schema Status Variables

The Performance Schema implements several status variables that provide information about instrumentation that could not be loaded orcreated due to memory constraints:

性能架构提供了⼏个变量,有关仪器仪表的信息由于内存限制⽆法被加载或创建:Performance_schema_cond_classes_lostPerformance_schema_cond_instances_lostPerformance_schema_file_classes_lostPerformance_schema_file_handles_lostPerformance_schema_file_instances_lostPerformance_schema_locker_lostPerformance_schema_mutex_classes_lostPerformance_schema_mutex_instances_lostPerformance_schema_rwlock_classes_lostPerformance_schema_rwlock_instances_lostPerformance_schema_table_handles_lostPerformance_schema_table_instances_lostPerformance_schema_thread_classes_lostPerformance_schema_thread_instances_lost

Prepared_stmt_count

The current number of prepared statements. (The maximum number of statements is given by the max_prepared_stmt_count systemvariable.)

预处理语句的数量。(语句的最⼤数量值是由系统变量max_prepared_stmt_count决定的。)

Qcache_free_blocks

查询缓存内⾃由内存块的数量。

Qcache_free_memory

⽤于查询缓存的⾃由内存的数量。

Qcache_hits

查询缓存被访问的次数。

Qcache_inserts

加⼊到缓存的查询数量。

Qcache_lowmem_prunes

由于内存较少从缓存删除的查询数量。

Qcache_not_cached

⾮缓存查询数(不可缓存,或由于query_cache_type设定值未缓存)。

Qcache_queries_in_cache

登记到缓存内的查询的数量。

Qcache_total_blocks

查询缓存内的总块数。

QueriesQuestions

已经发送给服务器的查询的个数。

RPL_semi_sync_xxx

以下变量只有当Master安装了半同步复制插件时可⽤。Rpl_semi_sync_master_clients

The number of semisynchronous slaves.半同步复制的Slave数量。

Rpl_semi_sync_master_net_avg_wait_time

The average time in microseconds the master waited for a slave reply.主等待从机响应的平均时间,以微秒为单位。Rpl_semi_sync_master_net_wait_time

The total time in microseconds the master waited for slave replies.主等待从机响应的总时间。Rpl_semi_sync_master_net_waits

The total number of times the master waited for slave replies.主等待从机响应的总次数。Rpl_semi_sync_master_no_times

The number of times the master turned off semisynchronous replication.主机关闭半同步复制的次数Rpl_semi_sync_master_no_tx

The number of commits that were not acknowledged successfully by a slave.Slave端未确认成功的提交数。Rpl_semi_sync_master_status

Whether semisynchronous replication currently is operational on the master. The value is ON if the plugin has been enabled and a commitacknowledgment has occurred. It is OFF if the plugin is not enabled or the master has fallen back to asynchronous replication due tocommit acknowledgment timeout.

⽆论半同步复制⽬前是否在主上运⾏。如果插件已经启⽤并且提交已经确认,则值为ON;如果插件没有启⽤或者主机由于提交超时回落到异步同步时,值为OFF。

Rpl_semi_sync_master_timefunc_failures

The number of times the master failed when calling time functions such as gettimeofday().主机调⽤类似gettimeofday()的时间函数失败的次数。Rpl_semi_sync_master_tx_avg_wait_time

The average time in microseconds the master waited for each transaction.主机等待每个事务的平均时间。Rpl_semi_sync_master_tx_wait_time

The total time in microseconds the master waited for transactions.主机等待事务的总时间。Rpl_semi_sync_master_tx_waits

The total number of times the master waited for transactions.主机等待事务的总次数。

Rpl_semi_sync_master_wait_pos_backtraverse

The total number of times the master waited for an event with binary coordinates lower than events waited for previously. This can occurwhen the order in which transactions start waiting for a reply is different from the order in which their binary log events are written.

主机等待⼀个⼆进制坐标的时间低于先前事务的等待时间的总次数。当事务开始等待答复的顺序不同于事务写⼊全⽇志的顺序时,可能发⽣这种情况。

Rpl_semi_sync_master_wait_sessions

The number of sessions currently waiting for slave replies.会话通常等待Slave答复的次数。Rpl_semi_sync_master_yes_tx

The number of commits that were acknowledged successfully by a slave.提交被Slave确认成功的次数。Rpl_semi_sync_slave_status

Whether semisynchronous replication currently is operational on the slave. This is ON if the plugin has been enabled and the slave I/Othread is running, OFF otherwise.

⽆论半同步复制是否在Slave端运⾏。如果插件被启⽤并且Slave I/O线程正在运⾏,则显⽰ON,否则显⽰OFF。Rpl_status

The status of fail-safe replication (not implemented). This variable is unused and is removed in MySQL 5.6.不安全⽽失败复制的状态(不执⾏)。这个变量没有启⽤且在MySQL 5.6版本中移除。

Select_full_join

没有使⽤索引的联接的数量。如果该值不为0,你应仔细检查表的索引。

Select_full_range_join

在引⽤的表中使⽤范围搜索的联接的数量。

Select_range

在第⼀个表中使⽤范围的联接的数量。⼀般情况不是关键问题,即使该值相当⼤。

Select_range_check

在每⼀⾏数据后对键值进⾏检查的不带键值的联接的数量。如果不为0,你应仔细检查表的索引。

Select_scan

对第⼀个表进⾏完全扫描的联接的数量。

Slave_heartbeat_period

Shows the replication heartbeat interval (in seconds) on a replication slave.显⽰⼀个Slave的复制⼼跳间隔。

Slave_open_temp_tables

当前由从SQL线程打开的临时表的数量。

Slave_received_heartbeats

This counter increments with each replication heartbeat received by a replication slave since the last time that the slave was restarted orreset, or a CHANGE MASTER TO statement was issued.

累计每个SLAVE从最后⼀次启动、复位或更换master到现在收到的⼼跳数。

Slave_retried_transactions

The total number of times since startup that the replication slave SQL thread has retried transactions.从启动以来SLAVE端尝试事务的总次数。

Slave_running

如果该服务器是连接到主服务器的从服务器,则该值为ON。

Slow_launch_threads

创建时间超过slow_launch_time秒的线程数。

Slow_queries

查询时间超过long_query_time秒的查询的个数

Sort_merge_passes

排序算法已经执⾏的合并的数量。如果这个变量值较⼤,应考虑增加sort_buffer_size系统变量的值。

Sort_range

在范围内执⾏的排序的数量。

Sort_rows

已经排序的⾏数。

Sort_scan

通过扫描表完成的排序的数量。

Ssl_xxx

⽤于SSL连接的变量。包括:Ssl_accept_renegotiatesSsl_accepts

Ssl_callback_cache_hitsSsl_cipherSsl_cipher_listSsl_client_connectsSsl_connect_renegotiatesSsl_ctx_verify_depthSsl_ctx_verify_modeSsl_default_timeoutSsl_finished_acceptsSsl_finished_connectsSsl_session_cache_hitsSsl_session_cache_missesSsl_session_cache_modeSsl_session_cache_overflowsSsl_session_cache_sizeSsl_session_cache_timeouts

Ssl_sessions_reused

Ssl_used_session_cache_entriesSsl_verify_depthSsl_verify_modeSsl_version

Table_locks_immediate

⽴即获得的表的锁的次数。

Table_locks_waited

不能⽴即获得的表的锁的次数。如果该值较⾼,并且有性能问题,你应⾸先优化查询,然后拆分表或使⽤复制

Tc_log_max_pages_usedTc_log_page_sizeTc_log_page_waitsThreads_cached

线程缓存内的线程的数量。

Threads_connected

当前打开的连接的数量。

Threads_created

创建⽤来处理连接的线程数。如果Threads_created较⼤,你可能要增加thread_cache_size值。缓存访问率的计算⽅法Threads_created/Connections。

Threads_running

激活的(⾮睡眠状态)线程数。

Uptime

服务器已经运⾏的时间(以秒为单位)。

Uptime_since_flush_status

The number of seconds since the most recent FLUSH STATUS statement.从上次执⾏FLUSH STATUS语句后经过的时间。

转载⾃:http://www.cnblogs.com/lenagt/archive/2012/06/06/2538240.html

因篇幅问题不能全部显示,请点此查看更多更全内容