MySQL 9.0.0
Source Code Documentation
mysqld.h File Reference

Go to the source code of this file.

Macros

#define TEST_PRINT_CACHED_TABLES   1
 
#define TEST_NO_KEY_GROUP   2
 
#define TEST_MIT_THREAD   4
 
#define OBSOLETE_TEST_BLOCKING   8
 
#define TEST_KEEP_TMP_TABLES   16
 
#define TEST_READCHECK   64
 Force use of readcheck. More...
 
#define TEST_NO_EXTRA   128
 
#define TEST_CORE_ON_SIGNAL   256
 Give core if signal. More...
 
#define TEST_NO_STACKTRACE   512
 
#define TEST_SIGINT   1024
 Allow sigint on threads. More...
 
#define TEST_SYNCHRONIZATION    2048
 get server to do sleep in \ some places More...
 
#define TEST_DO_QUICK_LEAK_CHECK    4096
 Do Valgrind leak check for \ each command. More...
 
#define TEST_NO_TEMP_TABLES    8192
 No temp table engine is loaded, so use dummy costs. More...
 
#define SPECIAL_NO_NEW_FUNC   2 /* Skip new functions */
 
#define SPECIAL_SKIP_SHOW_DB   4 /* Don't allow 'show db' */
 
#define SPECIAL_NO_RESOLVE   64 /* Don't use gethostname */
 
#define SPECIAL_SHORT_LOG_FORMAT   1024
 
#define mysql_tmpdir   (my_tmpdir(&mysql_tmpdir_list))
 
#define ER(X)   please_use_ER_THD_or_ER_DEFAULT_instead(X)
 

Typedefs

typedef Bitmap< 64 > Key_map
 
typedef int64 query_id_t
 

Enumerations

enum  enum_server_operational_state { SERVER_BOOTING , SERVER_OPERATING , SERVER_SHUTTING_DOWN }
 
enum  enum_replica_type_conversions { REPLICA_TYPE_CONVERSIONS_ALL_LOSSY , REPLICA_TYPE_CONVERSIONS_ALL_NON_LOSSY , REPLICA_TYPE_CONVERSIONS_ALL_UNSIGNED , REPLICA_TYPE_CONVERSIONS_ALL_SIGNED }
 
enum  enum_delay_key_write { DELAY_KEY_WRITE_NONE , DELAY_KEY_WRITE_ON , DELAY_KEY_WRITE_ALL }
 
enum  enum_binlog_error_action { IGNORE_ERROR = 0 , ABORT_SERVER = 1 }
 

Functions

bool signal_restart_server ()
 Signal the server thread for restart. More...
 
void kill_mysql (void)
 
void refresh_status ()
 Reset global and session status variables. More...
 
void reset_status_by_thd ()
 
bool is_secure_file_path (const char *path)
 Test a file path to determine if the path is compatible with the secure file path restriction. More...
 
ulong sql_rnd_with_mutex ()
 
struct System_status_varget_thd_status_var (THD *thd, bool *aggregated)
 
void thd_mem_cnt_alloc (THD *thd, size_t size, const char *key_name)
 
void thd_mem_cnt_free (THD *thd, size_t size)
 
void set_remaining_args (int argc, char **argv)
 
int init_common_variables ()
 
void my_init_signals ()
 
bool gtid_server_init ()
 GTID initialization. More...
 
void gtid_server_cleanup ()
 GTID cleanup destroys objects and reset their pointer. More...
 
void clean_up_mysqld_mutexes ()
 
enum_server_operational_state get_server_state ()
 Returns the current state of the server : booting, operational or shutting down. More...
 
int * get_remaining_argc ()
 
char *** get_remaining_argv ()
 
query_id_t next_query_id ()
 
bool connection_events_loop_aborted ()
 
static void set_connection_events_loop_aborted (bool value)
 
bool is_help_or_validate_option ()
 Check if –help option or –validate-config is specified. More...
 
bool mysqld_offline_mode ()
 Get mysqld offline mode. More...
 
void set_mysqld_offline_mode (bool value)
 Set offline mode with a given value. More...
 
bool mysqld_partial_revokes ()
 Get status partial_revokes on server. More...
 
void set_mysqld_partial_revokes (bool value)
 Set partial_revokes with a given value. More...
 
bool check_and_update_partial_revokes_sysvar (THD *thd)
 If there exists at least one restrictions on any user, then update global variables which track the partial_revokes. More...
 
void persisted_variables_refresh_keyring_support ()
 

Variables

bool dynamic_plugins_are_initialized
 Flag indicating if dynamic plugins have been loaded. More...
 
bool opt_large_files
 
bool server_id_supplied
 
bool opt_bin_log
 
bool opt_log_replica_updates
 
bool opt_log_unsafe_statements
 
bool opt_general_log
 
bool opt_slow_log
 
bool opt_general_log_raw
 
ulonglong log_output_options
 
bool opt_log_queries_not_using_indexes
 
ulong opt_log_throttle_queries_not_using_indexes
 
bool opt_log_slow_extra
 
bool opt_disable_networking
 
bool opt_skip_show_db
 
bool opt_skip_name_resolve
 
bool opt_help
 
bool opt_verbose
 
MYSQL_PLUGIN_IMPORT std::atomic< int32connection_events_loop_aborted_flag
 
long opt_upgrade_mode
 
bool opt_initialize
 
bool opt_safe_user_create
 
bool opt_local_infile
 
bool opt_myisam_use_mmap
 
bool opt_replica_compressed_protocol
 
ulong replica_exec_mode_options
 
Rpl_global_filter rpl_global_filter
 
Rpl_acf_configuration_handlerrpl_acf_configuration_handler
 
Source_IO_monitorrpl_source_io_monitor
 
int32_t opt_regexp_time_limit
 
int32_t opt_regexp_stack_limit
 
bool opt_debugging
 
bool opt_validate_config
 
ulonglong replica_type_conversions_options
 
bool read_only
 
bool opt_readonly
 
bool super_read_only
 
bool opt_super_readonly
 
bool lower_case_file_system
 
bool opt_require_secure_transport
 
bool opt_replica_preserve_commit_order
 
uint replica_rows_last_search_algorithm_used
 
ulong mts_parallel_option
 
bool opt_allow_suspicious_udfs
 
const char * opt_secure_file_priv
 
bool opt_log_slow_admin_statements
 
bool opt_log_slow_replica_statements
 
bool sp_automatic_privileges
 
bool opt_noacl
 
bool trust_function_creators
 
bool check_proxy_users
 
bool sha256_password_proxy_users
 
const char * mysqld_unix_port
 
char * default_tz_name
 
Time_zonedefault_tz
 
const char * default_storage_engine
 
const char * default_tmp_storage_engine
 
ulonglong temptable_max_ram
 
ulonglong temptable_max_mmap
 
bool temptable_use_mmap
 
bool using_udf_functions
 
bool locked_in_memory
 
bool opt_using_transactions
 
ulong current_pid
 
ulong binlog_expire_logs_seconds
 
bool opt_binlog_expire_logs_auto_purge
 
uint sync_binlog_period
 
uint sync_relaylog_period
 
uint sync_relayloginfo_period
 
uint sync_masterinfo_period
 
uint opt_mta_checkpoint_period
 
uint opt_mta_checkpoint_group
 
ulong opt_tc_log_size
 
ulong tc_log_max_pages_used
 
ulong tc_log_page_size
 
ulong tc_log_page_waits
 
bool relay_log_purge
 
bool relay_log_recovery
 
std::atomic< bool > offline_mode
 
uint test_flags
 
uint select_errors
 
uint ha_open_options
 
uint protocol_version
 
uint mysqld_port
 
ulong delay_key_write_options
 
ulong opt_log_timestamps
 
const char * timestamp_type_names []
 
char * opt_general_logname
 
char * opt_slow_logname
 
char * opt_bin_logname
 
char * opt_relay_logname
 
char * mysql_home_ptr
 
char * pidfile_name_ptr
 
uint default_password_lifetime
 
bool password_require_current
 
bool opt_partial_revokes
 
char * my_bind_addr_str
 
char * my_admin_bind_addr_str
 
uint mysqld_admin_port
 
bool listen_admin_interface_in_separate_thread
 
char glob_hostname [HOSTNAME_LENGTH+1]
 
char system_time_zone_dst_on [30]
 
char system_time_zone_dst_off [30]
 
char * opt_init_file
 
const char * opt_tc_log_file
 
char server_uuid [UUID_LENGTH+1]
 
const char * server_uuid_ptr
 
char server_build_id [42]
 
const char * server_build_id_ptr
 
const double log_10 [309]
 
ulong binlog_cache_use
 
ulong binlog_cache_disk_use
 
ulong binlog_stmt_cache_use
 
ulong binlog_stmt_cache_disk_use
 
ulong aborted_threads
 
ulong delayed_insert_timeout
 
ulong delayed_insert_limit
 
ulong delayed_queue_size
 
std::atomic< int32atomic_replica_open_temp_tables
 
ulong slow_launch_time
 
ulong table_cache_size
 
ulong schema_def_size
 
ulong stored_program_def_size
 
ulong table_def_size
 
ulong tablespace_def_size
 
MYSQL_PLUGIN_IMPORT ulong max_connections
 
ulong max_digest_length
 
ulong max_connect_errors
 
ulong connect_timeout
 
bool opt_replica_allow_batching
 
ulong slave_trans_retries
 
uint replica_net_timeout
 
ulong opt_mts_replica_parallel_workers
 
ulonglong opt_mts_pending_jobs_size_max
 
ulong rpl_stop_replica_timeout
 
ulong what_to_log
 
ulong flush_time
 
ulong max_prepared_stmt_count
 Limit of the total number of prepared statements in the server. More...
 
ulong prepared_stmt_count
 
ulong open_files_limit
 
bool clone_startup
 True, if restarted from a cloned database. More...
 
bool clone_recovery_error
 True, if clone recovery has failed. More...
 
ulong binlog_cache_size
 
ulong binlog_stmt_cache_size
 
ulonglong max_binlog_cache_size
 
ulonglong max_binlog_stmt_cache_size
 
int32 opt_binlog_max_flush_queue_time
 
long opt_binlog_group_commit_sync_delay
 
ulong opt_binlog_group_commit_sync_no_delay_count
 
ulong max_binlog_size
 
ulong max_relay_log_size
 
ulong replica_max_allowed_packet
 
ulong binlog_row_event_max_size
 
ulong binlog_checksum_options
 
ulong binlog_row_metadata
 
const char * binlog_checksum_type_names []
 BINLOG_CHECKSUM variable. More...
 
bool opt_source_verify_checksum
 
bool opt_replica_sql_verify_checksum
 
uint32 gtid_executed_compression_period
 
bool binlog_gtid_simple_recovery
 
ulong binlog_error_action
 
ulong locked_account_connection_count
 
const char * binlog_error_action_list []
 
char * opt_authentication_policy
 
ulong stored_program_cache_size
 Soft upper limit for number of sp_head objects that can be stored in the sp_cache for one connection. More...
 
ulong back_log
 
MYSQL_PLUGIN_IMPORT ulong server_id
 
time_t server_start_time
 
char * opt_mysql_tmpdir
 
size_t mysql_unpacked_real_data_home_len
 
MYSQL_PLUGIN_IMPORT MY_TMPDIR mysql_tmpdir_list
 
const char * show_comp_option_name []
 
const char * first_keyword
 
const char * binary_keyword
 
MYSQL_PLUGIN_IMPORT const char * my_localhost
 
const char * in_left_expr_name
 name of reference on left expression in rewritten IN subquery More...
 
SHOW_VAR status_vars []
 
struct System_variables max_system_variables
 
struct System_status_var global_status_var
 
struct aggregated_stats global_aggregated_stats
 
struct rand_struct sql_rand
 used by sql_class.cc:THD::THD() More...
 
handlertonmyisam_hton
 
handlertonheap_hton
 
handlertontemptable_hton
 
handlertoninnodb_hton
 
uint opt_server_id_bits
 
ulong opt_server_id_mask
 
const char * load_default_groups []
 
struct my_option my_long_early_options []
 
MYSQL_PLUGIN_IMPORT bool mysqld_server_started
 
MYSQL_PLUGIN_IMPORT int orig_argc
 
MYSQL_PLUGIN_IMPORT char ** orig_argv
 
bool server_shutting_down
 
my_thread_attr_t connection_attrib
 
LEX_STRING opt_init_connect
 
LEX_STRING opt_init_replica
 
ulong connection_errors_internal
 Number of connection errors from internal server errors. More...
 
ulong connection_errors_peer_addr
 Number of errors when reading the peer address. More...
 
char * opt_log_error_suppression_list
 
char * opt_log_error_services
 
char * opt_protocol_compression_algorithms
 
uint host_cache_size
 The size of the host_cache. More...
 
ulong log_error_verbosity
 
bool persisted_globals_load
 
bool opt_keyring_operations
 
bool opt_table_encryption_privilege_check
 
char * opt_keyring_migration_user
 
char * opt_keyring_migration_host
 
char * opt_keyring_migration_password
 
char * opt_keyring_migration_socket
 
char * opt_keyring_migration_source
 
char * opt_keyring_migration_destination
 
ulong opt_keyring_migration_port
 
ulonglong global_conn_mem_limit
 
ulonglong global_conn_mem_counter
 
bool migrate_connect_options
 Variable to check if connection related options are set as part of keyring migration. More...
 
LEX_CSTRING sql_statement_names [(uint) SQLCOM_END+1]
 
thread_local MEM_ROOT ** THR_MALLOC
 
PSI_file_key key_file_binlog_cache
 
PSI_file_key key_file_binlog_index_cache
 
PSI_mutex_key key_LOCK_tc
 
PSI_mutex_key key_hash_filo_lock
 
PSI_mutex_key key_LOCK_error_log
 
PSI_mutex_key key_LOCK_thd_data
 
PSI_mutex_key key_LOCK_thd_sysvar
 
PSI_mutex_key key_LOCK_thd_protocol
 
PSI_mutex_key key_LOCK_thd_security_ctx
 
PSI_mutex_key key_LOG_LOCK_log
 
PSI_mutex_key key_source_info_data_lock
 
PSI_mutex_key key_source_info_run_lock
 
PSI_mutex_key key_source_info_sleep_lock
 
PSI_mutex_key key_source_info_thd_lock
 
PSI_mutex_key key_source_info_rotate_lock
 
PSI_mutex_key key_mutex_replica_reporting_capability_err_lock
 
PSI_mutex_key key_relay_log_info_data_lock
 
PSI_mutex_key key_relay_log_info_sleep_lock
 
PSI_mutex_key key_relay_log_info_thd_lock
 
PSI_mutex_key key_relay_log_info_log_space_lock
 
PSI_mutex_key key_relay_log_info_run_lock
 
PSI_mutex_key key_mutex_slave_parallel_pend_jobs
 
PSI_mutex_key key_mutex_slave_parallel_worker
 
PSI_mutex_key key_mutex_slave_parallel_worker_count
 
PSI_mutex_key key_structure_guard_mutex
 
PSI_mutex_key key_TABLE_SHARE_LOCK_ha_data
 
PSI_mutex_key key_LOCK_query_plan
 
PSI_mutex_key key_LOCK_thd_query
 
PSI_mutex_key key_LOCK_cost_const
 
PSI_mutex_key key_LOCK_current_cond
 
PSI_mutex_key key_RELAYLOG_LOCK_commit
 
PSI_mutex_key key_RELAYLOG_LOCK_index
 
PSI_mutex_key key_RELAYLOG_LOCK_log
 
PSI_mutex_key key_RELAYLOG_LOCK_log_end_pos
 
PSI_mutex_key key_RELAYLOG_LOCK_sync
 
PSI_mutex_key key_RELAYLOG_LOCK_xids
 
PSI_mutex_key key_gtid_ensure_index_mutex
 
PSI_mutex_key key_mta_temp_table_LOCK
 
PSI_mutex_key key_mta_gaq_LOCK
 
PSI_mutex_key key_thd_timer_mutex
 
PSI_mutex_key key_monitor_info_run_lock
 
PSI_mutex_key key_LOCK_delegate_connection_mutex
 
PSI_mutex_key key_LOCK_group_replication_connection_mutex
 
PSI_mutex_key key_commit_order_manager_mutex
 
PSI_mutex_key key_mutex_replica_worker_hash
 
PSI_rwlock_key key_rwlock_LOCK_logger
 
PSI_rwlock_key key_rwlock_channel_map_lock
 
PSI_rwlock_key key_rwlock_channel_lock
 
PSI_rwlock_key key_rwlock_gtid_mode_lock
 
PSI_rwlock_key key_rwlock_receiver_tsid_lock
 
PSI_rwlock_key key_rwlock_rpl_filter_lock
 
PSI_rwlock_key key_rwlock_channel_to_filter_lock
 
PSI_rwlock_key key_rwlock_resource_group_mgr_map_lock
 
PSI_cond_key key_PAGE_cond
 
PSI_cond_key key_COND_active
 
PSI_cond_key key_COND_pool
 
PSI_cond_key key_COND_cache_status_changed
 
PSI_cond_key key_item_func_sleep_cond
 
PSI_cond_key key_source_info_data_cond
 
PSI_cond_key key_source_info_start_cond
 
PSI_cond_key key_source_info_stop_cond
 
PSI_cond_key key_source_info_sleep_cond
 
PSI_cond_key key_source_info_rotate_cond
 
PSI_cond_key key_relay_log_info_data_cond
 
PSI_cond_key key_relay_log_info_log_space_cond
 
PSI_cond_key key_relay_log_info_start_cond
 
PSI_cond_key key_relay_log_info_stop_cond
 
PSI_cond_key key_relay_log_info_sleep_cond
 
PSI_cond_key key_cond_slave_parallel_pend_jobs
 
PSI_cond_key key_cond_slave_parallel_worker
 
PSI_cond_key key_cond_mta_gaq
 
PSI_cond_key key_RELAYLOG_update_cond
 
PSI_cond_key key_gtid_ensure_index_cond
 
PSI_cond_key key_COND_thr_lock
 
PSI_cond_key key_cond_slave_worker_hash
 
PSI_cond_key key_commit_order_manager_cond
 
PSI_cond_key key_COND_group_replication_connection_cond_var
 
PSI_thread_key key_thread_bootstrap
 
PSI_thread_key key_thread_handle_manager
 
PSI_thread_key key_thread_one_connection
 
PSI_thread_key key_thread_compress_gtid_table
 
PSI_thread_key key_thread_parser_service
 
PSI_thread_key key_thread_handle_con_admin_sockets
 
PSI_cond_key key_monitor_info_run_cond
 
PSI_file_key key_file_binlog
 
PSI_file_key key_file_binlog_index
 
PSI_file_key key_file_dbopt
 
PSI_file_key key_file_ERRMSG
 
PSI_file_key key_select_to_file
 
PSI_file_key key_file_fileparser
 
PSI_file_key key_file_frm
 
PSI_file_key key_file_load
 
PSI_file_key key_file_loadfile
 
PSI_file_key key_file_log_event_data
 
PSI_file_key key_file_log_event_info
 
PSI_file_key key_file_misc
 
PSI_file_key key_file_tclog
 
PSI_file_key key_file_trg
 
PSI_file_key key_file_trn
 
PSI_file_key key_file_init
 
PSI_file_key key_file_general_log
 
PSI_file_key key_file_slow_log
 
PSI_file_key key_file_relaylog
 
PSI_file_key key_file_relaylog_cache
 
PSI_file_key key_file_relaylog_index
 
PSI_file_key key_file_relaylog_index_cache
 
PSI_file_key key_file_sdi
 
PSI_file_key key_file_hash_join
 
PSI_socket_key key_socket_tcpip
 
PSI_socket_key key_socket_unix
 
PSI_socket_key key_socket_client_connection
 
PSI_stage_info stage_after_create
 
PSI_stage_info stage_alter_inplace_prepare
 
PSI_stage_info stage_alter_inplace
 
PSI_stage_info stage_alter_inplace_commit
 
PSI_stage_info stage_changing_source
 
PSI_stage_info stage_checking_source_version
 
PSI_stage_info stage_checking_permissions
 
PSI_stage_info stage_cleaning_up
 
PSI_stage_info stage_closing_tables
 
PSI_stage_info stage_compressing_gtid_table
 
PSI_stage_info stage_connecting_to_source
 
PSI_stage_info stage_converting_heap_to_ondisk
 
PSI_stage_info stage_copy_to_tmp_table
 
PSI_stage_info stage_creating_table
 
PSI_stage_info stage_creating_tmp_table
 
PSI_stage_info stage_deleting_from_main_table
 
PSI_stage_info stage_deleting_from_reference_tables
 
PSI_stage_info stage_discard_or_import_tablespace
 
PSI_stage_info stage_end
 
PSI_stage_info stage_executing
 
PSI_stage_info stage_execution_of_init_command
 
PSI_stage_info stage_explaining
 
PSI_stage_info stage_finished_reading_one_binlog_switching_to_next_binlog
 
PSI_stage_info stage_flushing_applier_and_connection_metadata
 
PSI_stage_info stage_flushing_applier_metadata
 
PSI_stage_info stage_freeing_items
 
PSI_stage_info stage_fulltext_initialization
 
PSI_stage_info stage_init
 
PSI_stage_info stage_killing_replica
 
PSI_stage_info stage_logging_slow_query
 
PSI_stage_info stage_making_temp_file_append_before_load_data
 
PSI_stage_info stage_manage_keys
 
PSI_stage_info stage_source_has_sent_all_binlog_to_replica
 
PSI_stage_info stage_opening_tables
 
PSI_stage_info stage_optimizing
 
PSI_stage_info stage_preparing
 
PSI_stage_info stage_purging_old_relay_logs
 
PSI_stage_info stage_query_end
 
PSI_stage_info stage_queueing_source_event_to_the_relay_log
 
PSI_stage_info stage_reading_event_from_the_relay_log
 
PSI_stage_info stage_registering_replica_on_source
 
PSI_stage_info stage_removing_tmp_table
 
PSI_stage_info stage_rename
 
PSI_stage_info stage_rename_result_table
 
PSI_stage_info stage_requesting_binlog_dump
 
PSI_stage_info stage_searching_rows_for_update
 
PSI_stage_info stage_sending_binlog_event_to_replica
 
PSI_stage_info stage_setup
 
PSI_stage_info stage_replica_has_read_all_relay_log
 
PSI_stage_info stage_replica_reconnecting_after_failed_binlog_dump_request
 
PSI_stage_info stage_replica_reconnecting_after_failed_event_read
 
PSI_stage_info stage_replica_reconnecting_after_failed_registration_on_source
 
PSI_stage_info stage_replica_waiting_event_from_coordinator
 
PSI_stage_info stage_replica_waiting_for_workers_to_process_queue
 
PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_binlog_dump_request
 
PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_event_read
 
PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_registration_on_source
 
PSI_stage_info stage_replica_waiting_worker_queue
 
PSI_stage_info stage_replica_waiting_worker_to_free_events
 
PSI_stage_info stage_replica_waiting_worker_to_release_partition
 
PSI_stage_info stage_replica_waiting_workers_to_exit
 
PSI_stage_info stage_rpl_apply_row_evt_write
 
PSI_stage_info stage_rpl_apply_row_evt_update
 
PSI_stage_info stage_rpl_apply_row_evt_delete
 
PSI_stage_info stage_sql_thd_waiting_until_delay
 
PSI_stage_info stage_statistics
 
PSI_stage_info stage_system_lock
 
PSI_stage_info stage_update
 
PSI_stage_info stage_updating
 
PSI_stage_info stage_updating_main_table
 
PSI_stage_info stage_updating_reference_tables
 
PSI_stage_info stage_user_sleep
 
PSI_stage_info stage_verifying_table
 
PSI_stage_info stage_waiting_for_gtid_to_be_committed
 
PSI_stage_info stage_waiting_for_handler_commit
 
PSI_stage_info stage_waiting_for_source_to_send_event
 
PSI_stage_info stage_waiting_for_source_update
 
PSI_stage_info stage_waiting_for_relay_log_space
 
PSI_stage_info stage_waiting_for_replica_mutex_on_exit
 
PSI_stage_info stage_waiting_for_replica_thread_to_start
 
PSI_stage_info stage_waiting_for_table_flush
 
PSI_stage_info stage_waiting_for_the_next_event_in_relay_log
 
PSI_stage_info stage_waiting_for_the_replica_thread_to_advance_position
 
PSI_stage_info stage_waiting_to_finalize_termination
 
PSI_stage_info stage_worker_waiting_for_its_turn_to_commit
 
PSI_stage_info stage_worker_waiting_for_commit_parent
 
PSI_stage_info stage_suspending
 
PSI_stage_info stage_starting
 
PSI_stage_info stage_waiting_for_no_channel_reference
 
PSI_stage_info stage_hook_begin_trans
 
PSI_stage_info stage_binlog_transaction_compress
 
PSI_stage_info stage_binlog_transaction_decompress
 
PSI_stage_info stage_rpl_failover_fetching_source_member_details
 
PSI_stage_info stage_rpl_failover_updating_source_member_details
 
PSI_stage_info stage_rpl_failover_wait_before_next_fetch
 
PSI_stage_info stage_communication_delegation
 
PSI_stage_info stage_wait_on_commit_ticket
 
PSI_statement_info sql_statement_info [(uint) SQLCOM_END+1]
 Statement instrumentation keys (sql). More...
 
PSI_statement_info com_statement_info [(uint) COM_END+1]
 Statement instrumentation keys (com). More...
 
PSI_statement_info stmt_info_rpl
 Statement instrumentation key for replication. More...
 
struct st_VioSSLFdssl_acceptor_fd
 
bool opt_large_pages
 
uint opt_large_page_size
 
char lc_messages_dir [FN_REFLEN]
 
char * lc_messages_dir_ptr
 
const char * log_error_dest
 
MYSQL_PLUGIN_IMPORT char reg_ext [FN_EXTLEN]
 
MYSQL_PLUGIN_IMPORT uint reg_ext_length
 
MYSQL_PLUGIN_IMPORT uint lower_case_table_names
 
long tc_heuristic_recover
 
ulong specialflag
 
size_t mysql_data_home_len
 
const char * mysql_real_data_home_ptr
 
MYSQL_PLUGIN_IMPORT char * mysql_data_home
 
MYSQL_PLUGIN_IMPORT char server_version [SERVER_VERSION_LENGTH]
 
MYSQL_PLUGIN_IMPORT char mysql_real_data_home []
 
char mysql_unpacked_real_data_home []
 
MYSQL_PLUGIN_IMPORT struct System_variables global_system_variables
 
char default_logfile_name [FN_REFLEN]
 
bool log_bin_supplied
 
char default_binlogfile_name [FN_REFLEN]
 
MYSQL_PLUGIN_IMPORT char pidfile_name []
 
mysql_mutex_t LOCK_status
 
mysql_mutex_t LOCK_uuid_generator
 
mysql_mutex_t LOCK_crypt
 
mysql_mutex_t LOCK_manager
 
mysql_mutex_t LOCK_global_system_variables
 
mysql_mutex_t LOCK_user_conn
 
mysql_mutex_t LOCK_log_throttle_qni
 
mysql_mutex_t LOCK_prepared_stmt_count
 The below lock protects access to two global server variables: max_prepared_stmt_count and prepared_stmt_count. More...
 
mysql_mutex_t LOCK_replica_list
 Protects slave_list in rpl_source.cc; the list of currently running dump threads with metadata for the replica. More...
 
mysql_mutex_t LOCK_error_messages
 
mysql_mutex_t LOCK_sql_replica_skip_counter
 
mysql_mutex_t LOCK_replica_net_timeout
 
mysql_mutex_t LOCK_replica_trans_dep_tracker
 
mysql_mutex_t LOCK_mandatory_roles
 
mysql_mutex_t LOCK_password_history
 
mysql_mutex_t LOCK_password_reuse_interval
 
mysql_mutex_t LOCK_default_password_lifetime
 
mysql_mutex_t LOCK_server_started
 
mysql_mutex_t LOCK_reset_gtid_table
 
mysql_mutex_t LOCK_compress_gtid_table
 
mysql_mutex_t LOCK_keyring_operations
 
mysql_mutex_t LOCK_collect_instance_log
 
mysql_mutex_t LOCK_tls_ctx_options
 
mysql_mutex_t LOCK_admin_tls_ctx_options
 
mysql_mutex_t LOCK_rotate_binlog_master_key
 
mysql_mutex_t LOCK_partial_revokes
 
mysql_mutex_t LOCK_global_conn_mem_limit
 
mysql_mutex_t LOCK_authentication_policy
 
mysql_cond_t COND_server_started
 
mysql_cond_t COND_compress_gtid_table
 
mysql_cond_t COND_manager
 
mysql_rwlock_t LOCK_sys_init_connect
 
mysql_rwlock_t LOCK_sys_init_replica
 
mysql_rwlock_t LOCK_system_variables_hash
 
mysql_rwlock_t LOCK_server_shutting_down
 
ulong opt_ssl_fips_mode
 
char * opt_disabled_storage_engines
 
sigset_t mysqld_signal_mask
 
std::atomic< query_id_tatomic_global_query_id
 
LEX_STRING opt_mandatory_roles
 
bool opt_mandatory_roles_cache
 
bool opt_always_activate_granted_roles
 
mysql_component_t mysql_component_mysql_server
 
mysql_component_t mysql_component_performance_schema
 
mysql_service_registry_tsrv_registry
 
mysql_service_registry_tsrv_registry_no_lock
 
const mysql_service_dynamic_loader_scheme_file_tscheme_file_srv
 
const mysql_service_dynamic_loader_tdynamic_loader_srv
 
const mysql_service_registry_registration_tregistry_registration
 
const mysql_service_registry_registration_tregistry_registration_no_lock
 
Deployed_componentsg_deployed_components
 This variable holds handle to the object that's responsible for loading/unloading components from manifest file. More...
 
bool opt_persist_sensitive_variables_in_plaintext
 
int argc_cached
 Stores the value of argc during server start up that contains the count of arguments specified by the user in the configuration files and command line. More...
 
char ** argv_cached
 Stores the value of argv during server start up that contains the vector of arguments specified by the user in the configuration files and command line. More...
 
std::atomic< time_t > last_mixed_non_transactional_engine_warning
 Stores the last time the warning for non-composable engine is emitted. More...
 
const uint16_t mixed_non_transactional_engine_warning_period = 60 * 2
 The time period for which no warning for non-composable engines should be written to the error log after a similar warning was written. More...
 

Macro Definition Documentation

◆ ER

#define ER (   X)    please_use_ER_THD_or_ER_DEFAULT_instead(X)

◆ mysql_tmpdir

#define mysql_tmpdir   (my_tmpdir(&mysql_tmpdir_list))

◆ OBSOLETE_TEST_BLOCKING

#define OBSOLETE_TEST_BLOCKING   8

◆ SPECIAL_NO_NEW_FUNC

#define SPECIAL_NO_NEW_FUNC   2 /* Skip new functions */

◆ SPECIAL_NO_RESOLVE

#define SPECIAL_NO_RESOLVE   64 /* Don't use gethostname */

◆ SPECIAL_SHORT_LOG_FORMAT

#define SPECIAL_SHORT_LOG_FORMAT   1024

◆ SPECIAL_SKIP_SHOW_DB

#define SPECIAL_SKIP_SHOW_DB   4 /* Don't allow 'show db' */

◆ TEST_CORE_ON_SIGNAL

#define TEST_CORE_ON_SIGNAL   256

Give core if signal.

◆ TEST_DO_QUICK_LEAK_CHECK

#define TEST_DO_QUICK_LEAK_CHECK    4096

Do Valgrind leak check for \ each command.

◆ TEST_KEEP_TMP_TABLES

#define TEST_KEEP_TMP_TABLES   16

◆ TEST_MIT_THREAD

#define TEST_MIT_THREAD   4

◆ TEST_NO_EXTRA

#define TEST_NO_EXTRA   128

◆ TEST_NO_KEY_GROUP

#define TEST_NO_KEY_GROUP   2

◆ TEST_NO_STACKTRACE

#define TEST_NO_STACKTRACE   512

◆ TEST_NO_TEMP_TABLES

#define TEST_NO_TEMP_TABLES    8192

No temp table engine is loaded, so use dummy costs.

◆ TEST_PRINT_CACHED_TABLES

#define TEST_PRINT_CACHED_TABLES   1

◆ TEST_READCHECK

#define TEST_READCHECK   64

Force use of readcheck.

◆ TEST_SIGINT

#define TEST_SIGINT   1024

Allow sigint on threads.

◆ TEST_SYNCHRONIZATION

#define TEST_SYNCHRONIZATION    2048

get server to do sleep in \ some places

Typedef Documentation

◆ Key_map

typedef Bitmap<64> Key_map

◆ query_id_t

typedef int64 query_id_t

Enumeration Type Documentation

◆ enum_binlog_error_action

Enumerator
IGNORE_ERROR 

Ignore the error and let server continue without binlogging.

ABORT_SERVER 

Abort the server.

◆ enum_delay_key_write

Enumerator
DELAY_KEY_WRITE_NONE 
DELAY_KEY_WRITE_ON 
DELAY_KEY_WRITE_ALL 

◆ enum_replica_type_conversions

Enumerator
REPLICA_TYPE_CONVERSIONS_ALL_LOSSY 
REPLICA_TYPE_CONVERSIONS_ALL_NON_LOSSY 
REPLICA_TYPE_CONVERSIONS_ALL_UNSIGNED 
REPLICA_TYPE_CONVERSIONS_ALL_SIGNED 

◆ enum_server_operational_state

Enumerator
SERVER_BOOTING 
SERVER_OPERATING 
SERVER_SHUTTING_DOWN 

Function Documentation

◆ check_and_update_partial_revokes_sysvar()

bool check_and_update_partial_revokes_sysvar ( THD thd)

If there exists at least one restrictions on any user, then update global variables which track the partial_revokes.

Parameters
thdTHD handle
Returns
a bool indicating partial_revokes status of the server.
Return values
trueParital revokes exists; updated the global variables.
falsePartial revokes does not exist.

◆ clean_up_mysqld_mutexes()

void clean_up_mysqld_mutexes ( )

◆ connection_events_loop_aborted()

bool connection_events_loop_aborted ( )
inline

◆ get_remaining_argc()

int * get_remaining_argc ( )

◆ get_remaining_argv()

char *** get_remaining_argv ( )

◆ get_server_state()

enum_server_operational_state get_server_state ( )

Returns the current state of the server : booting, operational or shutting down.

Returns
SERVER_BOOTING Server is not operational. It is starting. SERVER_OPERATING Server is fully initialized and operating. SERVER_SHUTTING_DOWN Server is shutting down.

◆ get_thd_status_var()

struct System_status_var * get_thd_status_var ( THD thd,
bool *  aggregated 
)

◆ gtid_server_cleanup()

void gtid_server_cleanup ( )

GTID cleanup destroys objects and reset their pointer.

Function is reentrant.

◆ gtid_server_init()

bool gtid_server_init ( )

GTID initialization.

Returns
true if allocation does not succeed false if OK

◆ init_common_variables()

int init_common_variables ( )

◆ is_help_or_validate_option()

bool is_help_or_validate_option ( )
inline

Check if –help option or –validate-config is specified.

Return values
falseNeither 'help' or 'validate-config' option is enabled.
trueEither 'help' or 'validate-config' or both options are enabled.

◆ is_secure_file_path()

bool is_secure_file_path ( const char *  path)

Test a file path to determine if the path is compatible with the secure file path restriction.

Parameters
pathnull terminated character string
Return values
trueThe path is secure
falseThe path isn't secure

◆ kill_mysql()

void kill_mysql ( void  )

◆ my_init_signals()

void my_init_signals ( )

◆ mysqld_offline_mode()

bool mysqld_offline_mode ( )
inline

Get mysqld offline mode.

Returns
a bool indicating the offline mode status of the server.

◆ mysqld_partial_revokes()

bool mysqld_partial_revokes ( )

Get status partial_revokes on server.

Returns
a bool indicating partial_revokes status of the server.
Return values
trueParital revokes is ON
flasePartial revokes is OFF

◆ next_query_id()

query_id_t next_query_id ( )
inline

◆ persisted_variables_refresh_keyring_support()

void persisted_variables_refresh_keyring_support ( )

◆ refresh_status()

void refresh_status ( )

Reset global and session status variables.

◆ reset_status_by_thd()

void reset_status_by_thd ( )

◆ set_connection_events_loop_aborted()

static void set_connection_events_loop_aborted ( bool  value)
inlinestatic

◆ set_mysqld_offline_mode()

void set_mysqld_offline_mode ( bool  value)
inline

Set offline mode with a given value.

Parameters
valuetrue or false indicating the offline mode status of server.

◆ set_mysqld_partial_revokes()

void set_mysqld_partial_revokes ( bool  value)

Set partial_revokes with a given value.

Parameters
valuetrue or false indicating the status of partial revokes turned ON/OFF on server.

◆ set_remaining_args()

void set_remaining_args ( int  argc,
char **  argv 
)

◆ signal_restart_server()

bool signal_restart_server ( )

Signal the server thread for restart.

Returns
false if the thread has been successfully signalled for restart else true.

◆ sql_rnd_with_mutex()

ulong sql_rnd_with_mutex ( )

◆ thd_mem_cnt_alloc()

void thd_mem_cnt_alloc ( THD thd,
size_t  size,
const char *  key_name 
)

◆ thd_mem_cnt_free()

void thd_mem_cnt_free ( THD thd,
size_t  size 
)

Variable Documentation

◆ aborted_threads

ulong aborted_threads
extern

◆ argc_cached

int argc_cached
extern

Stores the value of argc during server start up that contains the count of arguments specified by the user in the configuration files and command line.

The server refers the cached argument count during plugin and component installation.

◆ argv_cached

char** argv_cached
extern

Stores the value of argv during server start up that contains the vector of arguments specified by the user in the configuration files and command line.

The server refers the cached argument vector during plugin and component installation.

◆ atomic_global_query_id

std::atomic<query_id_t> atomic_global_query_id
extern

◆ atomic_replica_open_temp_tables

std::atomic<int32> atomic_replica_open_temp_tables
extern

◆ back_log

ulong back_log
extern

◆ binary_keyword

const char * binary_keyword

◆ binlog_cache_disk_use

ulong binlog_cache_disk_use

◆ binlog_cache_size

ulong binlog_cache_size
extern

◆ binlog_cache_use

ulong binlog_cache_use
extern

◆ binlog_checksum_options

ulong binlog_checksum_options
extern

◆ binlog_checksum_type_names

const char* binlog_checksum_type_names[]
extern

BINLOG_CHECKSUM variable.

◆ binlog_error_action

ulong binlog_error_action
extern

◆ binlog_error_action_list

const char* binlog_error_action_list[]
extern

◆ binlog_expire_logs_seconds

ulong binlog_expire_logs_seconds
extern

◆ binlog_gtid_simple_recovery

bool binlog_gtid_simple_recovery
extern

◆ binlog_row_event_max_size

ulong binlog_row_event_max_size
extern

◆ binlog_row_metadata

ulong binlog_row_metadata
extern

◆ binlog_stmt_cache_disk_use

ulong binlog_stmt_cache_disk_use

◆ binlog_stmt_cache_size

ulong binlog_stmt_cache_size

◆ binlog_stmt_cache_use

ulong binlog_stmt_cache_use
extern

◆ check_proxy_users

bool check_proxy_users
extern

◆ clone_recovery_error

bool clone_recovery_error
extern

True, if clone recovery has failed.

For managed server we restart server again with old database files.

◆ clone_startup

bool clone_startup
extern

True, if restarted from a cloned database.

This information is needed by GR to set some configurations right after clone.

◆ com_statement_info

PSI_statement_info com_statement_info[(uint) COM_END+1]
extern

Statement instrumentation keys (com).

The last entry, at [COM_END], is for packet errors.

◆ COND_compress_gtid_table

mysql_cond_t COND_compress_gtid_table
extern

◆ COND_manager

mysql_cond_t COND_manager
extern

◆ COND_server_started

mysql_cond_t COND_server_started
extern

◆ connect_timeout

ulong connect_timeout

◆ connection_errors_internal

ulong connection_errors_internal
extern

Number of connection errors from internal server errors.

◆ connection_errors_peer_addr

ulong connection_errors_peer_addr
extern

Number of errors when reading the peer address.

◆ connection_events_loop_aborted_flag

MYSQL_PLUGIN_IMPORT std::atomic<int32> connection_events_loop_aborted_flag
extern

◆ current_pid

ulong current_pid
extern

◆ default_binlogfile_name

char default_binlogfile_name[FN_REFLEN]
extern

◆ default_logfile_name

char default_logfile_name[FN_REFLEN]
extern

◆ default_password_lifetime

uint default_password_lifetime
extern

◆ default_storage_engine

const char* default_storage_engine
extern

◆ default_tmp_storage_engine

const char* default_tmp_storage_engine
extern

◆ default_tz

Time_zone* default_tz
extern

◆ default_tz_name

char* default_tz_name
extern

◆ delay_key_write_options

ulong delay_key_write_options
extern

◆ delayed_insert_limit

ulong delayed_insert_limit
extern

◆ delayed_insert_timeout

ulong delayed_insert_timeout
extern

◆ delayed_queue_size

ulong delayed_queue_size

◆ dynamic_loader_srv

const mysql_service_dynamic_loader_t* dynamic_loader_srv
extern

◆ dynamic_plugins_are_initialized

bool dynamic_plugins_are_initialized
extern

Flag indicating if dynamic plugins have been loaded.

Only to be accessed by main thread.

◆ first_keyword

const char* first_keyword
extern

◆ flush_time

ulong flush_time

◆ g_deployed_components

Deployed_components* g_deployed_components
extern

This variable holds handle to the object that's responsible for loading/unloading components from manifest file.

◆ glob_hostname

char glob_hostname[HOSTNAME_LENGTH+1]
extern

◆ global_aggregated_stats

struct aggregated_stats global_aggregated_stats
extern

◆ global_conn_mem_counter

ulonglong global_conn_mem_counter
extern

◆ global_conn_mem_limit

ulonglong global_conn_mem_limit
extern

◆ global_status_var

struct System_status_var global_status_var
extern

◆ global_system_variables

MYSQL_PLUGIN_IMPORT struct System_variables global_system_variables
extern

◆ gtid_executed_compression_period

uint32 gtid_executed_compression_period
extern

◆ ha_open_options

uint ha_open_options

◆ heap_hton

handlerton* heap_hton
extern

◆ host_cache_size

uint host_cache_size
extern

The size of the host_cache.

◆ in_left_expr_name

const char* in_left_expr_name
extern

name of reference on left expression in rewritten IN subquery

◆ innodb_hton

handlerton* innodb_hton
extern

◆ key_commit_order_manager_cond

PSI_cond_key key_commit_order_manager_cond
extern

◆ key_commit_order_manager_mutex

PSI_mutex_key key_commit_order_manager_mutex
extern

◆ key_COND_active

PSI_cond_key key_COND_active
extern

◆ key_COND_cache_status_changed

PSI_cond_key key_COND_cache_status_changed
extern

◆ key_COND_group_replication_connection_cond_var

PSI_cond_key key_COND_group_replication_connection_cond_var
extern

◆ key_cond_mta_gaq

PSI_cond_key key_cond_mta_gaq
extern

◆ key_COND_pool

PSI_cond_key key_COND_pool
extern

◆ key_cond_slave_parallel_pend_jobs

PSI_cond_key key_cond_slave_parallel_pend_jobs
extern

◆ key_cond_slave_parallel_worker

PSI_cond_key key_cond_slave_parallel_worker
extern

◆ key_cond_slave_worker_hash

PSI_cond_key key_cond_slave_worker_hash
extern

◆ key_COND_thr_lock

PSI_cond_key key_COND_thr_lock
extern

◆ key_file_binlog

PSI_file_key key_file_binlog
extern

◆ key_file_binlog_cache

PSI_file_key key_file_binlog_cache
extern

◆ key_file_binlog_index

PSI_file_key key_file_binlog_index
extern

◆ key_file_binlog_index_cache

PSI_file_key key_file_binlog_index_cache
extern

◆ key_file_dbopt

PSI_file_key key_file_dbopt
extern

◆ key_file_ERRMSG

PSI_file_key key_file_ERRMSG
extern

◆ key_file_fileparser

PSI_file_key key_file_fileparser
extern

◆ key_file_frm

PSI_file_key key_file_frm
extern

◆ key_file_general_log

PSI_file_key key_file_general_log
extern

◆ key_file_hash_join

PSI_file_key key_file_hash_join
extern

◆ key_file_init

PSI_file_key key_file_init
extern

◆ key_file_load

PSI_file_key key_file_load
extern

◆ key_file_loadfile

PSI_file_key key_file_loadfile
extern

◆ key_file_log_event_data

PSI_file_key key_file_log_event_data
extern

◆ key_file_log_event_info

PSI_file_key key_file_log_event_info
extern

◆ key_file_misc

PSI_file_key key_file_misc
extern

◆ key_file_relaylog

PSI_file_key key_file_relaylog
extern

◆ key_file_relaylog_cache

PSI_file_key key_file_relaylog_cache
extern

◆ key_file_relaylog_index

PSI_file_key key_file_relaylog_index
extern

◆ key_file_relaylog_index_cache

PSI_file_key key_file_relaylog_index_cache
extern

◆ key_file_sdi

PSI_file_key key_file_sdi
extern

◆ key_file_slow_log

PSI_file_key key_file_slow_log
extern

◆ key_file_tclog

PSI_file_key key_file_tclog
extern

◆ key_file_trg

PSI_file_key key_file_trg
extern

◆ key_file_trn

PSI_file_key key_file_trn
extern

◆ key_gtid_ensure_index_cond

PSI_cond_key key_gtid_ensure_index_cond
extern

◆ key_gtid_ensure_index_mutex

PSI_mutex_key key_gtid_ensure_index_mutex
extern

◆ key_hash_filo_lock

PSI_mutex_key key_hash_filo_lock
extern

◆ key_item_func_sleep_cond

PSI_cond_key key_item_func_sleep_cond
extern

◆ key_LOCK_cost_const

PSI_mutex_key key_LOCK_cost_const
extern

◆ key_LOCK_current_cond

PSI_mutex_key key_LOCK_current_cond
extern

◆ key_LOCK_delegate_connection_mutex

PSI_mutex_key key_LOCK_delegate_connection_mutex
extern

◆ key_LOCK_error_log

PSI_mutex_key key_LOCK_error_log
extern

◆ key_LOCK_group_replication_connection_mutex

PSI_mutex_key key_LOCK_group_replication_connection_mutex
extern

◆ key_LOCK_query_plan

PSI_mutex_key key_LOCK_query_plan
extern

◆ key_LOCK_tc

PSI_mutex_key key_LOCK_tc
extern

◆ key_LOCK_thd_data

PSI_mutex_key key_LOCK_thd_data
extern

◆ key_LOCK_thd_protocol

PSI_mutex_key key_LOCK_thd_protocol
extern

◆ key_LOCK_thd_query

PSI_mutex_key key_LOCK_thd_query
extern

◆ key_LOCK_thd_security_ctx

PSI_mutex_key key_LOCK_thd_security_ctx
extern

◆ key_LOCK_thd_sysvar

PSI_mutex_key key_LOCK_thd_sysvar
extern

◆ key_LOG_LOCK_log

PSI_mutex_key key_LOG_LOCK_log
extern

◆ key_monitor_info_run_cond

PSI_cond_key key_monitor_info_run_cond
extern

◆ key_monitor_info_run_lock

PSI_mutex_key key_monitor_info_run_lock
extern

◆ key_mta_gaq_LOCK

PSI_mutex_key key_mta_gaq_LOCK
extern

◆ key_mta_temp_table_LOCK

PSI_mutex_key key_mta_temp_table_LOCK
extern

◆ key_mutex_replica_reporting_capability_err_lock

PSI_mutex_key key_mutex_replica_reporting_capability_err_lock
extern

◆ key_mutex_replica_worker_hash

PSI_mutex_key key_mutex_replica_worker_hash
extern

◆ key_mutex_slave_parallel_pend_jobs

PSI_mutex_key key_mutex_slave_parallel_pend_jobs
extern

◆ key_mutex_slave_parallel_worker

PSI_mutex_key key_mutex_slave_parallel_worker
extern

◆ key_mutex_slave_parallel_worker_count

PSI_mutex_key key_mutex_slave_parallel_worker_count
extern

◆ key_PAGE_cond

PSI_cond_key key_PAGE_cond
extern

◆ key_relay_log_info_data_cond

PSI_cond_key key_relay_log_info_data_cond
extern

◆ key_relay_log_info_data_lock

PSI_mutex_key key_relay_log_info_data_lock
extern

◆ key_relay_log_info_log_space_cond

PSI_cond_key key_relay_log_info_log_space_cond
extern

◆ key_relay_log_info_log_space_lock

PSI_mutex_key key_relay_log_info_log_space_lock
extern

◆ key_relay_log_info_run_lock

PSI_mutex_key key_relay_log_info_run_lock
extern

◆ key_relay_log_info_sleep_cond

PSI_cond_key key_relay_log_info_sleep_cond
extern

◆ key_relay_log_info_sleep_lock

PSI_mutex_key key_relay_log_info_sleep_lock
extern

◆ key_relay_log_info_start_cond

PSI_cond_key key_relay_log_info_start_cond
extern

◆ key_relay_log_info_stop_cond

PSI_cond_key key_relay_log_info_stop_cond
extern

◆ key_relay_log_info_thd_lock

PSI_mutex_key key_relay_log_info_thd_lock
extern

◆ key_RELAYLOG_LOCK_commit

PSI_mutex_key key_RELAYLOG_LOCK_commit
extern

◆ key_RELAYLOG_LOCK_index

PSI_mutex_key key_RELAYLOG_LOCK_index
extern

◆ key_RELAYLOG_LOCK_log

PSI_mutex_key key_RELAYLOG_LOCK_log
extern

◆ key_RELAYLOG_LOCK_log_end_pos

PSI_mutex_key key_RELAYLOG_LOCK_log_end_pos
extern

◆ key_RELAYLOG_LOCK_sync

PSI_mutex_key key_RELAYLOG_LOCK_sync
extern

◆ key_RELAYLOG_LOCK_xids

PSI_mutex_key key_RELAYLOG_LOCK_xids
extern

◆ key_RELAYLOG_update_cond

PSI_cond_key key_RELAYLOG_update_cond
extern

◆ key_rwlock_channel_lock

PSI_rwlock_key key_rwlock_channel_lock
extern

◆ key_rwlock_channel_map_lock

PSI_rwlock_key key_rwlock_channel_map_lock
extern

◆ key_rwlock_channel_to_filter_lock

PSI_rwlock_key key_rwlock_channel_to_filter_lock
extern

◆ key_rwlock_gtid_mode_lock

PSI_rwlock_key key_rwlock_gtid_mode_lock
extern

◆ key_rwlock_LOCK_logger

PSI_rwlock_key key_rwlock_LOCK_logger
extern

◆ key_rwlock_receiver_tsid_lock

PSI_rwlock_key key_rwlock_receiver_tsid_lock
extern

◆ key_rwlock_resource_group_mgr_map_lock

PSI_rwlock_key key_rwlock_resource_group_mgr_map_lock
extern

◆ key_rwlock_rpl_filter_lock

PSI_rwlock_key key_rwlock_rpl_filter_lock
extern

◆ key_select_to_file

PSI_file_key key_select_to_file
extern

◆ key_socket_client_connection

PSI_socket_key key_socket_client_connection
extern

◆ key_socket_tcpip

PSI_socket_key key_socket_tcpip
extern

◆ key_socket_unix

PSI_socket_key key_socket_unix
extern

◆ key_source_info_data_cond

PSI_cond_key key_source_info_data_cond
extern

◆ key_source_info_data_lock

PSI_mutex_key key_source_info_data_lock
extern

◆ key_source_info_rotate_cond

PSI_cond_key key_source_info_rotate_cond
extern

◆ key_source_info_rotate_lock

PSI_mutex_key key_source_info_rotate_lock
extern

◆ key_source_info_run_lock

PSI_mutex_key key_source_info_run_lock
extern

◆ key_source_info_sleep_cond

PSI_cond_key key_source_info_sleep_cond
extern

◆ key_source_info_sleep_lock

PSI_mutex_key key_source_info_sleep_lock
extern

◆ key_source_info_start_cond

PSI_cond_key key_source_info_start_cond
extern

◆ key_source_info_stop_cond

PSI_cond_key key_source_info_stop_cond
extern

◆ key_source_info_thd_lock

PSI_mutex_key key_source_info_thd_lock
extern

◆ key_structure_guard_mutex

PSI_mutex_key key_structure_guard_mutex
extern

◆ key_TABLE_SHARE_LOCK_ha_data

PSI_mutex_key key_TABLE_SHARE_LOCK_ha_data
extern

◆ key_thd_timer_mutex

PSI_mutex_key key_thd_timer_mutex
extern

◆ key_thread_bootstrap

PSI_thread_key key_thread_bootstrap
extern

◆ key_thread_compress_gtid_table

PSI_thread_key key_thread_compress_gtid_table
extern

◆ key_thread_handle_con_admin_sockets

PSI_thread_key key_thread_handle_con_admin_sockets
extern

◆ key_thread_handle_manager

PSI_thread_key key_thread_handle_manager
extern

◆ key_thread_one_connection

PSI_thread_key key_thread_one_connection
extern

◆ key_thread_parser_service

PSI_thread_key key_thread_parser_service
extern

◆ last_mixed_non_transactional_engine_warning

std::atomic<time_t> last_mixed_non_transactional_engine_warning
extern

Stores the last time the warning for non-composable engine is emitted.

◆ lc_messages_dir

char lc_messages_dir[FN_REFLEN]
extern

◆ lc_messages_dir_ptr

char* lc_messages_dir_ptr
extern

◆ listen_admin_interface_in_separate_thread

bool listen_admin_interface_in_separate_thread
extern

◆ load_default_groups

const char* load_default_groups[]
extern

◆ LOCK_admin_tls_ctx_options

mysql_mutex_t LOCK_admin_tls_ctx_options
extern

◆ LOCK_authentication_policy

mysql_mutex_t LOCK_authentication_policy
extern

◆ LOCK_collect_instance_log

mysql_mutex_t LOCK_collect_instance_log
extern

◆ LOCK_compress_gtid_table

mysql_mutex_t LOCK_compress_gtid_table
extern

◆ LOCK_crypt

mysql_mutex_t LOCK_crypt
extern

◆ LOCK_default_password_lifetime

mysql_mutex_t LOCK_default_password_lifetime
extern

◆ LOCK_error_messages

mysql_mutex_t LOCK_error_messages
extern

◆ LOCK_global_conn_mem_limit

mysql_mutex_t LOCK_global_conn_mem_limit
extern

◆ LOCK_global_system_variables

mysql_mutex_t LOCK_global_system_variables
extern

◆ LOCK_keyring_operations

mysql_mutex_t LOCK_keyring_operations
extern

◆ LOCK_log_throttle_qni

mysql_mutex_t LOCK_log_throttle_qni
extern

◆ LOCK_manager

mysql_mutex_t LOCK_manager
extern

◆ LOCK_mandatory_roles

mysql_mutex_t LOCK_mandatory_roles
extern

◆ LOCK_partial_revokes

mysql_mutex_t LOCK_partial_revokes
extern

◆ LOCK_password_history

mysql_mutex_t LOCK_password_history
extern

◆ LOCK_password_reuse_interval

mysql_mutex_t LOCK_password_reuse_interval
extern

◆ LOCK_prepared_stmt_count

mysql_mutex_t LOCK_prepared_stmt_count
extern

The below lock protects access to two global server variables: max_prepared_stmt_count and prepared_stmt_count.

These variables set the limit and hold the current total number of prepared statements in the server, respectively. As PREPARE/DEALLOCATE rate in a loaded server may be fairly high, we need a dedicated lock.

◆ LOCK_replica_list

mysql_mutex_t LOCK_replica_list
extern

Protects slave_list in rpl_source.cc; the list of currently running dump threads with metadata for the replica.

◆ LOCK_replica_net_timeout

mysql_mutex_t LOCK_replica_net_timeout
extern

◆ LOCK_replica_trans_dep_tracker

mysql_mutex_t LOCK_replica_trans_dep_tracker
extern

◆ LOCK_reset_gtid_table

mysql_mutex_t LOCK_reset_gtid_table
extern

◆ LOCK_rotate_binlog_master_key

mysql_mutex_t LOCK_rotate_binlog_master_key
extern

◆ LOCK_server_shutting_down

mysql_rwlock_t LOCK_server_shutting_down
extern

◆ LOCK_server_started

mysql_mutex_t LOCK_server_started
extern

◆ LOCK_sql_replica_skip_counter

mysql_mutex_t LOCK_sql_replica_skip_counter
extern

◆ LOCK_status

mysql_mutex_t LOCK_status
extern

◆ LOCK_sys_init_connect

mysql_rwlock_t LOCK_sys_init_connect
extern

◆ LOCK_sys_init_replica

mysql_rwlock_t LOCK_sys_init_replica
extern

◆ LOCK_system_variables_hash

mysql_rwlock_t LOCK_system_variables_hash
extern

◆ LOCK_tls_ctx_options

mysql_mutex_t LOCK_tls_ctx_options
extern

◆ LOCK_user_conn

mysql_mutex_t LOCK_user_conn
extern

◆ LOCK_uuid_generator

mysql_mutex_t LOCK_uuid_generator
extern

◆ locked_account_connection_count

ulong locked_account_connection_count
extern

◆ locked_in_memory

bool locked_in_memory
extern

◆ log_10

const double log_10[309]
extern

◆ log_bin_supplied

bool log_bin_supplied
extern

◆ log_error_dest

const char* log_error_dest
extern

◆ log_error_verbosity

ulong log_error_verbosity
extern

◆ log_output_options

ulonglong log_output_options
extern

◆ lower_case_file_system

bool lower_case_file_system
extern

◆ lower_case_table_names

MYSQL_PLUGIN_IMPORT uint lower_case_table_names
extern

◆ max_binlog_cache_size

ulonglong max_binlog_cache_size
extern

◆ max_binlog_size

ulong max_binlog_size
extern

◆ max_binlog_stmt_cache_size

ulonglong max_binlog_stmt_cache_size

◆ max_connect_errors

ulong max_connect_errors
extern

◆ max_connections

MYSQL_PLUGIN_IMPORT ulong max_connections
extern

◆ max_digest_length

ulong max_digest_length
extern

◆ max_prepared_stmt_count

ulong max_prepared_stmt_count
extern

Limit of the total number of prepared statements in the server.

Is necessary to protect the server against out-of-memory attacks.

◆ max_relay_log_size

ulong max_relay_log_size

◆ max_system_variables

struct System_variables max_system_variables
extern

◆ migrate_connect_options

bool migrate_connect_options
extern

Variable to check if connection related options are set as part of keyring migration.

◆ mixed_non_transactional_engine_warning_period

const uint16_t mixed_non_transactional_engine_warning_period = 60 * 2

The time period for which no warning for non-composable engines should be written to the error log after a similar warning was written.

◆ mts_parallel_option

ulong mts_parallel_option
extern

◆ my_admin_bind_addr_str

char* my_admin_bind_addr_str
extern

◆ my_bind_addr_str

char* my_bind_addr_str
extern

◆ my_localhost

MYSQL_PLUGIN_IMPORT const char* my_localhost
extern

◆ my_long_early_options

struct my_option my_long_early_options[]
extern

◆ myisam_hton

handlerton* myisam_hton
extern

◆ mysql_component_mysql_server

mysql_component_t mysql_component_mysql_server
extern

◆ mysql_component_performance_schema

mysql_component_t mysql_component_performance_schema
extern

◆ mysql_data_home

MYSQL_PLUGIN_IMPORT char* mysql_data_home
extern

◆ mysql_data_home_len

size_t mysql_data_home_len
extern

◆ mysql_home_ptr

char* mysql_home_ptr
extern

◆ mysql_real_data_home

MYSQL_PLUGIN_IMPORT char mysql_real_data_home[]
extern

◆ mysql_real_data_home_ptr

const char* mysql_real_data_home_ptr
extern

◆ mysql_tmpdir_list

MYSQL_PLUGIN_IMPORT MY_TMPDIR mysql_tmpdir_list
extern

◆ mysql_unpacked_real_data_home

char mysql_unpacked_real_data_home[]
extern

◆ mysql_unpacked_real_data_home_len

size_t mysql_unpacked_real_data_home_len
extern

◆ mysqld_admin_port

uint mysqld_admin_port
extern

◆ mysqld_port

uint mysqld_port

◆ mysqld_server_started

MYSQL_PLUGIN_IMPORT bool mysqld_server_started

◆ mysqld_signal_mask

sigset_t mysqld_signal_mask
extern

◆ mysqld_unix_port

const char* mysqld_unix_port
extern

◆ offline_mode

std::atomic<bool> offline_mode
extern

◆ open_files_limit

ulong open_files_limit
extern

◆ opt_allow_suspicious_udfs

bool opt_allow_suspicious_udfs
extern

◆ opt_always_activate_granted_roles

bool opt_always_activate_granted_roles
extern

◆ opt_authentication_policy

char* opt_authentication_policy
extern

◆ opt_bin_log

bool opt_bin_log
extern

◆ opt_bin_logname

char * opt_bin_logname

◆ opt_binlog_expire_logs_auto_purge

bool opt_binlog_expire_logs_auto_purge
extern

◆ opt_binlog_group_commit_sync_delay

long opt_binlog_group_commit_sync_delay
extern

◆ opt_binlog_group_commit_sync_no_delay_count

ulong opt_binlog_group_commit_sync_no_delay_count
extern

◆ opt_binlog_max_flush_queue_time

int32 opt_binlog_max_flush_queue_time
extern

◆ opt_debugging

bool opt_debugging
extern

◆ opt_disable_networking

bool opt_disable_networking
extern

◆ opt_disabled_storage_engines

char* opt_disabled_storage_engines
extern

◆ opt_general_log

bool opt_general_log
extern

◆ opt_general_log_raw

bool opt_general_log_raw

◆ opt_general_logname

char* opt_general_logname
extern

◆ opt_help

bool opt_help
extern

◆ opt_init_connect

LEX_STRING opt_init_connect
extern

◆ opt_init_file

char* opt_init_file
extern

◆ opt_init_replica

LEX_STRING opt_init_replica

◆ opt_initialize

bool opt_initialize
extern

◆ opt_keyring_migration_destination

char* opt_keyring_migration_destination
extern

◆ opt_keyring_migration_host

char* opt_keyring_migration_host
extern

◆ opt_keyring_migration_password

char* opt_keyring_migration_password
extern

◆ opt_keyring_migration_port

ulong opt_keyring_migration_port
extern

◆ opt_keyring_migration_socket

char* opt_keyring_migration_socket
extern

◆ opt_keyring_migration_source

char* opt_keyring_migration_source
extern

◆ opt_keyring_migration_user

char* opt_keyring_migration_user
extern

◆ opt_keyring_operations

bool opt_keyring_operations
extern

◆ opt_large_files

bool opt_large_files
extern

◆ opt_large_page_size

uint opt_large_page_size
extern

◆ opt_large_pages

bool opt_large_pages
extern

◆ opt_local_infile

bool opt_local_infile
extern

◆ opt_log_error_services

char* opt_log_error_services
extern

◆ opt_log_error_suppression_list

char* opt_log_error_suppression_list
extern

◆ opt_log_queries_not_using_indexes

bool opt_log_queries_not_using_indexes
extern

◆ opt_log_replica_updates

bool opt_log_replica_updates
extern

◆ opt_log_slow_admin_statements

bool opt_log_slow_admin_statements
extern

◆ opt_log_slow_extra

bool opt_log_slow_extra
extern

◆ opt_log_slow_replica_statements

bool opt_log_slow_replica_statements

◆ opt_log_throttle_queries_not_using_indexes

ulong opt_log_throttle_queries_not_using_indexes
extern

◆ opt_log_timestamps

ulong opt_log_timestamps
extern

◆ opt_log_unsafe_statements

bool opt_log_unsafe_statements
extern

◆ opt_mandatory_roles

LEX_STRING opt_mandatory_roles
extern

◆ opt_mandatory_roles_cache

bool opt_mandatory_roles_cache
extern

◆ opt_mta_checkpoint_group

uint opt_mta_checkpoint_group

◆ opt_mta_checkpoint_period

uint opt_mta_checkpoint_period

◆ opt_mts_pending_jobs_size_max

ulonglong opt_mts_pending_jobs_size_max
extern

◆ opt_mts_replica_parallel_workers

ulong opt_mts_replica_parallel_workers
extern

◆ opt_myisam_use_mmap

bool opt_myisam_use_mmap

◆ opt_mysql_tmpdir

char* opt_mysql_tmpdir
extern

◆ opt_noacl

bool opt_noacl

◆ opt_partial_revokes

bool opt_partial_revokes
extern

◆ opt_persist_sensitive_variables_in_plaintext

bool opt_persist_sensitive_variables_in_plaintext
extern

◆ opt_protocol_compression_algorithms

char* opt_protocol_compression_algorithms
extern

◆ opt_readonly

bool opt_readonly

◆ opt_regexp_stack_limit

int32_t opt_regexp_stack_limit
extern

◆ opt_regexp_time_limit

int32_t opt_regexp_time_limit
extern

◆ opt_replica_allow_batching

bool opt_replica_allow_batching
extern

◆ opt_replica_compressed_protocol

bool opt_replica_compressed_protocol
extern

◆ opt_replica_preserve_commit_order

bool opt_replica_preserve_commit_order
extern

◆ opt_replica_sql_verify_checksum

bool opt_replica_sql_verify_checksum
extern

◆ opt_require_secure_transport

bool opt_require_secure_transport
extern

◆ opt_safe_user_create

bool opt_safe_user_create
extern

◆ opt_secure_file_priv

const char* opt_secure_file_priv
extern

◆ opt_server_id_bits

uint opt_server_id_bits
extern

◆ opt_server_id_mask

ulong opt_server_id_mask
extern

◆ opt_skip_name_resolve

bool opt_skip_name_resolve
extern

◆ opt_skip_show_db

bool opt_skip_show_db

◆ opt_slow_log

bool opt_slow_log

◆ opt_slow_logname

char * opt_slow_logname

◆ opt_source_verify_checksum

bool opt_source_verify_checksum
extern

◆ opt_ssl_fips_mode

ulong opt_ssl_fips_mode
extern

◆ opt_super_readonly

bool opt_super_readonly

◆ opt_table_encryption_privilege_check

bool opt_table_encryption_privilege_check
extern

◆ opt_tc_log_file

const char* opt_tc_log_file
extern

◆ opt_tc_log_size

ulong opt_tc_log_size
extern

◆ opt_upgrade_mode

long opt_upgrade_mode
extern

◆ opt_using_transactions

bool opt_using_transactions
extern

◆ opt_validate_config

bool opt_validate_config
extern

◆ opt_verbose

bool opt_verbose
extern

◆ orig_argc

MYSQL_PLUGIN_IMPORT int orig_argc

◆ orig_argv

MYSQL_PLUGIN_IMPORT char** orig_argv

◆ password_require_current

bool password_require_current
extern

◆ persisted_globals_load

bool persisted_globals_load
extern

◆ pidfile_name

MYSQL_PLUGIN_IMPORT char pidfile_name[]
extern

◆ pidfile_name_ptr

char * pidfile_name_ptr

◆ prepared_stmt_count

ulong prepared_stmt_count

◆ protocol_version

uint protocol_version
extern

◆ read_only

bool read_only
extern

◆ reg_ext

MYSQL_PLUGIN_IMPORT char reg_ext[FN_EXTLEN]
extern

◆ reg_ext_length

MYSQL_PLUGIN_IMPORT uint reg_ext_length
extern

◆ registry_registration

const mysql_service_registry_registration_t* registry_registration
extern

◆ registry_registration_no_lock

const mysql_service_registry_registration_t* registry_registration_no_lock
extern

◆ relay_log_purge

bool relay_log_purge
extern

◆ relay_log_recovery

bool relay_log_recovery
extern

◆ replica_exec_mode_options

ulong replica_exec_mode_options
extern

◆ replica_max_allowed_packet

ulong replica_max_allowed_packet
extern

◆ replica_net_timeout

uint replica_net_timeout
extern

◆ replica_rows_last_search_algorithm_used

uint replica_rows_last_search_algorithm_used
extern

◆ replica_type_conversions_options

ulonglong replica_type_conversions_options
extern

◆ rpl_acf_configuration_handler

Rpl_acf_configuration_handler* rpl_acf_configuration_handler
extern

◆ rpl_global_filter

Rpl_global_filter rpl_global_filter
extern

◆ rpl_source_io_monitor

Source_IO_monitor* rpl_source_io_monitor
extern

◆ rpl_stop_replica_timeout

ulong rpl_stop_replica_timeout
extern

◆ schema_def_size

ulong schema_def_size
extern

◆ scheme_file_srv

const mysql_service_dynamic_loader_scheme_file_t* scheme_file_srv
extern

◆ select_errors

uint select_errors

◆ server_build_id

char server_build_id[42]
extern

◆ server_build_id_ptr

const char* server_build_id_ptr
extern

◆ server_id

MYSQL_PLUGIN_IMPORT ulong server_id

◆ server_shutting_down

bool server_shutting_down
extern

◆ server_start_time

time_t server_start_time
extern

◆ server_uuid

char server_uuid[UUID_LENGTH+1]
extern

◆ server_uuid_ptr

const char* server_uuid_ptr
extern

◆ server_version

◆ sha256_password_proxy_users

bool sha256_password_proxy_users

◆ show_comp_option_name

const char* show_comp_option_name[]
extern

◆ slave_trans_retries

ulong slave_trans_retries
extern

◆ slow_launch_time

ulong slow_launch_time
extern

◆ sp_automatic_privileges

bool sp_automatic_privileges
extern

◆ specialflag

ulong specialflag
extern

◆ sql_rand

struct rand_struct sql_rand
extern

used by sql_class.cc:THD::THD()

◆ sql_statement_info

PSI_statement_info sql_statement_info[(uint) SQLCOM_END+1]
extern

Statement instrumentation keys (sql).

The last entry, at [SQLCOM_END], is for parsing errors.

◆ sql_statement_names

LEX_CSTRING sql_statement_names[(uint) SQLCOM_END+1]
extern

◆ srv_registry

mysql_service_registry_t* srv_registry
extern

◆ srv_registry_no_lock

mysql_service_registry_t* srv_registry_no_lock
extern

◆ ssl_acceptor_fd

struct st_VioSSLFd* ssl_acceptor_fd
extern

◆ stage_after_create

PSI_stage_info stage_after_create
extern

◆ stage_alter_inplace

PSI_stage_info stage_alter_inplace
extern

◆ stage_alter_inplace_commit

PSI_stage_info stage_alter_inplace_commit
extern

◆ stage_alter_inplace_prepare

PSI_stage_info stage_alter_inplace_prepare
extern

◆ stage_binlog_transaction_compress

PSI_stage_info stage_binlog_transaction_compress
extern

◆ stage_binlog_transaction_decompress

PSI_stage_info stage_binlog_transaction_decompress
extern

◆ stage_changing_source

PSI_stage_info stage_changing_source
extern

◆ stage_checking_permissions

PSI_stage_info stage_checking_permissions
extern

◆ stage_checking_source_version

PSI_stage_info stage_checking_source_version
extern

◆ stage_cleaning_up

PSI_stage_info stage_cleaning_up
extern

◆ stage_closing_tables

PSI_stage_info stage_closing_tables
extern

◆ stage_communication_delegation

PSI_stage_info stage_communication_delegation
extern

◆ stage_compressing_gtid_table

PSI_stage_info stage_compressing_gtid_table
extern

◆ stage_connecting_to_source

PSI_stage_info stage_connecting_to_source
extern

◆ stage_converting_heap_to_ondisk

PSI_stage_info stage_converting_heap_to_ondisk
extern

◆ stage_copy_to_tmp_table

PSI_stage_info stage_copy_to_tmp_table
extern

◆ stage_creating_table

PSI_stage_info stage_creating_table
extern

◆ stage_creating_tmp_table

PSI_stage_info stage_creating_tmp_table
extern

◆ stage_deleting_from_main_table

PSI_stage_info stage_deleting_from_main_table
extern

◆ stage_deleting_from_reference_tables

PSI_stage_info stage_deleting_from_reference_tables
extern

◆ stage_discard_or_import_tablespace

PSI_stage_info stage_discard_or_import_tablespace
extern

◆ stage_end

PSI_stage_info stage_end
extern

◆ stage_executing

PSI_stage_info stage_executing
extern

◆ stage_execution_of_init_command

PSI_stage_info stage_execution_of_init_command
extern

◆ stage_explaining

PSI_stage_info stage_explaining
extern

◆ stage_finished_reading_one_binlog_switching_to_next_binlog

PSI_stage_info stage_finished_reading_one_binlog_switching_to_next_binlog
extern

◆ stage_flushing_applier_and_connection_metadata

PSI_stage_info stage_flushing_applier_and_connection_metadata
extern

◆ stage_flushing_applier_metadata

PSI_stage_info stage_flushing_applier_metadata
extern

◆ stage_freeing_items

PSI_stage_info stage_freeing_items
extern

◆ stage_fulltext_initialization

PSI_stage_info stage_fulltext_initialization
extern

◆ stage_hook_begin_trans

PSI_stage_info stage_hook_begin_trans
extern

◆ stage_init

PSI_stage_info stage_init
extern

◆ stage_killing_replica

PSI_stage_info stage_killing_replica
extern

◆ stage_logging_slow_query

PSI_stage_info stage_logging_slow_query
extern

◆ stage_making_temp_file_append_before_load_data

PSI_stage_info stage_making_temp_file_append_before_load_data
extern

◆ stage_manage_keys

PSI_stage_info stage_manage_keys
extern

◆ stage_opening_tables

PSI_stage_info stage_opening_tables
extern

◆ stage_optimizing

PSI_stage_info stage_optimizing
extern

◆ stage_preparing

PSI_stage_info stage_preparing
extern

◆ stage_purging_old_relay_logs

PSI_stage_info stage_purging_old_relay_logs
extern

◆ stage_query_end

PSI_stage_info stage_query_end
extern

◆ stage_queueing_source_event_to_the_relay_log

PSI_stage_info stage_queueing_source_event_to_the_relay_log
extern

◆ stage_reading_event_from_the_relay_log

PSI_stage_info stage_reading_event_from_the_relay_log
extern

◆ stage_registering_replica_on_source

PSI_stage_info stage_registering_replica_on_source
extern

◆ stage_removing_tmp_table

PSI_stage_info stage_removing_tmp_table
extern

◆ stage_rename

PSI_stage_info stage_rename
extern

◆ stage_rename_result_table

PSI_stage_info stage_rename_result_table
extern

◆ stage_replica_has_read_all_relay_log

PSI_stage_info stage_replica_has_read_all_relay_log
extern

◆ stage_replica_reconnecting_after_failed_binlog_dump_request

PSI_stage_info stage_replica_reconnecting_after_failed_binlog_dump_request
extern

◆ stage_replica_reconnecting_after_failed_event_read

PSI_stage_info stage_replica_reconnecting_after_failed_event_read
extern

◆ stage_replica_reconnecting_after_failed_registration_on_source

PSI_stage_info stage_replica_reconnecting_after_failed_registration_on_source
extern

◆ stage_replica_waiting_event_from_coordinator

PSI_stage_info stage_replica_waiting_event_from_coordinator
extern

◆ stage_replica_waiting_for_workers_to_process_queue

PSI_stage_info stage_replica_waiting_for_workers_to_process_queue
extern

◆ stage_replica_waiting_to_reconnect_after_failed_binlog_dump_request

PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_binlog_dump_request
extern

◆ stage_replica_waiting_to_reconnect_after_failed_event_read

PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_event_read
extern

◆ stage_replica_waiting_to_reconnect_after_failed_registration_on_source

PSI_stage_info stage_replica_waiting_to_reconnect_after_failed_registration_on_source
extern

◆ stage_replica_waiting_worker_queue

PSI_stage_info stage_replica_waiting_worker_queue
extern

◆ stage_replica_waiting_worker_to_free_events

PSI_stage_info stage_replica_waiting_worker_to_free_events
extern

◆ stage_replica_waiting_worker_to_release_partition

PSI_stage_info stage_replica_waiting_worker_to_release_partition
extern

◆ stage_replica_waiting_workers_to_exit

PSI_stage_info stage_replica_waiting_workers_to_exit
extern

◆ stage_requesting_binlog_dump

PSI_stage_info stage_requesting_binlog_dump
extern

◆ stage_rpl_apply_row_evt_delete

PSI_stage_info stage_rpl_apply_row_evt_delete
extern

◆ stage_rpl_apply_row_evt_update

PSI_stage_info stage_rpl_apply_row_evt_update
extern

◆ stage_rpl_apply_row_evt_write

PSI_stage_info stage_rpl_apply_row_evt_write
extern

◆ stage_rpl_failover_fetching_source_member_details

PSI_stage_info stage_rpl_failover_fetching_source_member_details
extern

◆ stage_rpl_failover_updating_source_member_details

PSI_stage_info stage_rpl_failover_updating_source_member_details
extern

◆ stage_rpl_failover_wait_before_next_fetch

PSI_stage_info stage_rpl_failover_wait_before_next_fetch
extern

◆ stage_searching_rows_for_update

PSI_stage_info stage_searching_rows_for_update
extern

◆ stage_sending_binlog_event_to_replica

PSI_stage_info stage_sending_binlog_event_to_replica
extern

◆ stage_setup

PSI_stage_info stage_setup
extern

◆ stage_source_has_sent_all_binlog_to_replica

PSI_stage_info stage_source_has_sent_all_binlog_to_replica
extern

◆ stage_sql_thd_waiting_until_delay

PSI_stage_info stage_sql_thd_waiting_until_delay
extern

◆ stage_starting

PSI_stage_info stage_starting
extern

◆ stage_statistics

PSI_stage_info stage_statistics
extern

◆ stage_suspending

PSI_stage_info stage_suspending
extern

◆ stage_system_lock

PSI_stage_info stage_system_lock
extern

◆ stage_update

PSI_stage_info stage_update
extern

◆ stage_updating

PSI_stage_info stage_updating
extern

◆ stage_updating_main_table

PSI_stage_info stage_updating_main_table
extern

◆ stage_updating_reference_tables

PSI_stage_info stage_updating_reference_tables
extern

◆ stage_user_sleep

PSI_stage_info stage_user_sleep
extern

◆ stage_verifying_table

PSI_stage_info stage_verifying_table
extern

◆ stage_wait_on_commit_ticket

PSI_stage_info stage_wait_on_commit_ticket
extern

◆ stage_waiting_for_gtid_to_be_committed

PSI_stage_info stage_waiting_for_gtid_to_be_committed
extern

◆ stage_waiting_for_handler_commit

PSI_stage_info stage_waiting_for_handler_commit
extern

◆ stage_waiting_for_no_channel_reference

PSI_stage_info stage_waiting_for_no_channel_reference
extern

◆ stage_waiting_for_relay_log_space

PSI_stage_info stage_waiting_for_relay_log_space
extern

◆ stage_waiting_for_replica_mutex_on_exit

PSI_stage_info stage_waiting_for_replica_mutex_on_exit
extern

◆ stage_waiting_for_replica_thread_to_start

PSI_stage_info stage_waiting_for_replica_thread_to_start
extern

◆ stage_waiting_for_source_to_send_event

PSI_stage_info stage_waiting_for_source_to_send_event
extern

◆ stage_waiting_for_source_update

PSI_stage_info stage_waiting_for_source_update
extern

◆ stage_waiting_for_table_flush

PSI_stage_info stage_waiting_for_table_flush
extern

◆ stage_waiting_for_the_next_event_in_relay_log

PSI_stage_info stage_waiting_for_the_next_event_in_relay_log
extern

◆ stage_waiting_for_the_replica_thread_to_advance_position

PSI_stage_info stage_waiting_for_the_replica_thread_to_advance_position
extern

◆ stage_waiting_to_finalize_termination

PSI_stage_info stage_waiting_to_finalize_termination
extern

◆ stage_worker_waiting_for_commit_parent

PSI_stage_info stage_worker_waiting_for_commit_parent
extern

◆ stage_worker_waiting_for_its_turn_to_commit

PSI_stage_info stage_worker_waiting_for_its_turn_to_commit
extern

◆ status_vars

SHOW_VAR status_vars[]
extern

◆ stmt_info_rpl

PSI_statement_info stmt_info_rpl
extern

Statement instrumentation key for replication.

◆ stored_program_cache_size

ulong stored_program_cache_size
extern

Soft upper limit for number of sp_head objects that can be stored in the sp_cache for one connection.

◆ stored_program_def_size

ulong stored_program_def_size
extern

◆ super_read_only

bool super_read_only
extern

◆ sync_masterinfo_period

uint sync_masterinfo_period

◆ sync_relaylog_period

uint sync_relaylog_period

◆ sync_relayloginfo_period

uint sync_relayloginfo_period

◆ system_time_zone_dst_off

char system_time_zone_dst_off[30]

◆ system_time_zone_dst_on

char system_time_zone_dst_on[30]
extern

◆ table_cache_size

ulong table_cache_size
extern

◆ table_def_size

ulong table_def_size
extern

◆ tablespace_def_size

ulong tablespace_def_size
extern

◆ tc_heuristic_recover

long tc_heuristic_recover
extern

◆ tc_log_max_pages_used

ulong tc_log_max_pages_used

◆ tc_log_page_size

ulong tc_log_page_size

◆ tc_log_page_waits

ulong tc_log_page_waits
extern

◆ temptable_hton

handlerton* temptable_hton
extern

◆ temptable_max_mmap

ulonglong temptable_max_mmap
extern

◆ temptable_max_ram

ulonglong temptable_max_ram
extern

◆ temptable_use_mmap

bool temptable_use_mmap
extern

◆ test_flags

uint test_flags
extern

◆ THR_MALLOC

thread_local MEM_ROOT** THR_MALLOC
extern

◆ timestamp_type_names

const char* timestamp_type_names[]
extern

◆ trust_function_creators

bool trust_function_creators
extern

◆ using_udf_functions

bool using_udf_functions
extern

◆ what_to_log

ulong what_to_log
extern