|
static bool | innobase::component_services::intitialize_service_handles () |
| Initialize component service handles. More...
|
|
static void | innobase::component_services::deinitialize_service_handles () |
| Deinitialize component service handles. More...
|
|
static bool | EQ_CURRENT_THD (THD *thd) |
|
static void | release_plugin_services () |
| Release all acquired services from mysql server. More...
|
|
static void | acquire_plugin_services () |
| Acquire required services from mysql server. More...
|
|
static rec_format_t | get_row_format (ulong row_format) |
| Return the InnoDB ROW_FORMAT enum value. More...
|
|
static void | trx_deregister_from_2pc (trx_t *trx) |
| Note that a transaction has been deregistered. More...
|
|
static float | innobase_fts_retrieve_ranking (FT_INFO *fts_hdl) |
| Retrieve the FTS Relevance Ranking result for doc with doc_id of m_prebuilt->fts_doc_id. More...
|
|
static void | innobase_fts_close_ranking (FT_INFO *fts_hdl) |
| Free the memory for the FTS handler. More...
|
|
static float | innobase_fts_find_ranking (FT_INFO *fts_hdl, uchar *, uint) |
| Find and Retrieve the FTS Relevance Ranking result for doc with doc_id of m_prebuilt->fts_doc_id. More...
|
|
static uint | innobase_fts_get_version () |
|
static ulonglong | innobase_fts_flags () |
|
static ulonglong | innobase_fts_retrieve_docid (FT_INFO_EXT *fts_hdl) |
| Find and Retrieve the FTS doc_id for the current result row. More...
|
|
static ulonglong | innobase_fts_count_matches (FT_INFO_EXT *fts_hdl) |
| Find and retrieve the size of the current result. More...
|
|
static void | doublewrite_update (THD *thd, SYS_VAR *var, void *var_ptr, const void *save) |
| Plugin update function to handle validation and then switch the innodb_doublewrite mode. More...
|
|
static int | innodb_check_session_admin (THD *thd, SYS_VAR *var, void *save, struct st_mysql_value *value) |
| Check if SESSION_VARIABLES_ADMIN granted. More...
|
|
static int | innodb_stopword_table_validate (THD *thd, SYS_VAR *var, void *save, struct st_mysql_value *value) |
| Check whether valid argument given to innobase_*_stopword_table. More...
|
|
static int | innodb_tmpdir_validate (THD *thd, SYS_VAR *, void *save, struct st_mysql_value *value) |
| Validate passed-in "value" is a valid directory name. More...
|
|
static uint | get_field_offset (const TABLE *table, const Field *field) |
| Gets field offset for a field in a table. More...
|
|
static | MYSQL_THDVAR_BOOL (table_locks, PLUGIN_VAR_OPCMDARG, "Enable InnoDB locking in LOCK TABLES", nullptr, nullptr, true) |
|
static | MYSQL_THDVAR_BOOL (strict_mode, PLUGIN_VAR_OPCMDARG, "Use strict mode when evaluating create options.", innodb_check_session_admin, nullptr, true) |
|
static | MYSQL_THDVAR_BOOL (ft_enable_stopword, PLUGIN_VAR_OPCMDARG, "Create FTS index with stopword.", nullptr, nullptr, true) |
|
static | MYSQL_THDVAR_ULONG (lock_wait_timeout, PLUGIN_VAR_RQCMDARG, "Timeout in seconds an InnoDB transaction may wait " "for a lock before being rolled back. Values above " "100000000 disable the timeout.", nullptr, nullptr, 50, 1, 1024 *1024 *1024, 0) |
|
static | MYSQL_THDVAR_STR (ft_user_stopword_table, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_MEMALLOC, "User supplied stopword table name, effective in the session level.", innodb_stopword_table_validate, nullptr, nullptr) |
|
static | MYSQL_THDVAR_STR (tmpdir, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_MEMALLOC, "Directory for temporary non-tablespace files.", innodb_tmpdir_validate, nullptr, nullptr) |
|
static | MYSQL_THDVAR_ULONG (parallel_read_threads, PLUGIN_VAR_RQCMDARG, "Number of threads to do parallel read.", nullptr, nullptr, std::clamp(ulong{std::thread::hardware_concurrency()/8}, 4UL, ulong{Parallel_reader::MAX_THREADS}), 1, Parallel_reader::MAX_THREADS, 0) |
|
static | MYSQL_THDVAR_ULONG (ddl_buffer_size, PLUGIN_VAR_RQCMDARG, "Maximum size of memory to use (in bytes) for DDL.", nullptr, nullptr, 1048576, 65536, 4294967295, 0) |
|
static | MYSQL_THDVAR_ULONG (ddl_threads, PLUGIN_VAR_RQCMDARG, "Maximum number of threads to use for DDL.", nullptr, nullptr, 4, 1, 64, 0) |
|
static INNOBASE_SHARE * | get_share (const char *table_name) |
| Handling the shared INNOBASE_SHARE structure that is needed to provide table locking. More...
|
|
static void | free_share (INNOBASE_SHARE *share) |
| Free the shared object that was registered with get_share(). More...
|
|
static int | innobase_close_connection (handlerton *hton, THD *thd) |
| Frees a possible InnoDB trx object associated with the current THD. More...
|
|
static void | innobase_kill_connection (handlerton *hton, THD *thd) |
| Cancel any pending lock request associated with the current THD. More...
|
|
static int | innobase_commit (handlerton *hton, THD *thd, bool commit_trx) |
| Commits a transaction in an InnoDB database or marks an SQL statement ended. More...
|
|
static int | innobase_rollback (handlerton *hton, THD *thd, bool rollback_trx) |
| Rolls back a transaction to a savepoint. More...
|
|
static bool | innobase_write_ddl_drop_schema (handlerton *hton, const char *schema_name) |
| Writes DELETE_SCHEMA_DIRECTORY_LOG for DROP SCHEMA. More...
|
|
static bool | innobase_write_ddl_create_schema (handlerton *hton, const char *schema_name) |
| Writes DELETE_SCHEMA_DIRECTORY_LOG for CREATE SCHEMA. More...
|
|
static int | innobase_rollback_to_savepoint (handlerton *hton, THD *thd, void *savepoint) |
| Rolls back a transaction to a savepoint. More...
|
|
static bool | innobase_rollback_to_savepoint_can_release_mdl (handlerton *hton, THD *thd) |
| Check whether innodb state allows to safely release MDL locks after rollback to savepoint. More...
|
|
static int | innobase_savepoint (handlerton *hton, THD *thd, void *savepoint) |
| Sets a transaction savepoint. More...
|
|
static int | innobase_release_savepoint (handlerton *hton, THD *thd, void *savepoint) |
| Release transaction savepoint name. More...
|
|
static handler * | innobase_create_handler (handlerton *hton, TABLE_SHARE *table, bool partitioned, MEM_ROOT *mem_root) |
| Function for constructing an InnoDB table handler instance. More...
|
|
static bool | innobase_get_table_statistics (const char *db_name, const char *table_name, dd::Object_id se_private_id, const dd::Properties &ts_se_private_data, const dd::Properties &tbl_se_private_data, uint stat_flags, ha_statistics *stats) |
| Retrieve table satistics. More...
|
|
static bool | innobase_get_index_column_cardinality (const char *db_name, const char *table_name, const char *index_name, uint index_ordinal_position, uint column_ordinal_position, dd::Object_id se_private_id, ulonglong *cardinality) |
| Retrieve index column cardinality. More...
|
|
static bool | innobase_get_tablespace_statistics (const char *tablespace_name, const char *file_name, const dd::Properties &ts_se_private_data, ha_tablespace_statistics *stats) |
| Retrieve ha_tablespace_statistics for the tablespace. More...
|
|
static bool | innobase_get_tablespace_type (const dd::Tablespace &space, Tablespace_type *space_type) |
| Retrieve the tablespace type. More...
|
|
static bool | innobase_get_tablespace_type_by_name (const char *tablespace_name, Tablespace_type *space_type) |
| Get the tablespace type given the name. More...
|
|
static void | innobase_post_ddl (THD *thd) |
| Perform post-commit/rollback cleanup after DDL statement. More...
|
|
static bool | innodb_check_fk_column_compat (const Ha_fk_column_type *child_column_type, const Ha_fk_column_type *parent_column_type, bool check_charsets) |
| Check if types of child and parent columns in foreign key are compatible. More...
|
|
static void | innobase_commit_concurrency_init_default () |
| Initialize the default value of innodb_commit_concurrency. More...
|
|
static int | innobase_xa_prepare (handlerton *hton, THD *thd, bool all) |
| This function is used to prepare an X/Open XA distributed transaction. More...
|
|
static int | innobase_xa_recover (handlerton *hton, XA_recover_txn *txn_list, uint len, MEM_ROOT *mem_root) |
| This function is used to recover X/Open XA distributed transactions. More...
|
|
static int | innobase_xa_recover_prepared_in_tc (handlerton *hton, Xa_state_list &xa_list) |
| Find prepared transactions that are marked as prepared in TC, for recovery purposes. More...
|
|
static xa_status_code | innobase_commit_by_xid (handlerton *hton, XID *xid) |
| This function is used to commit one X/Open XA distributed transaction which is in the prepared state. More...
|
|
static xa_status_code | innobase_rollback_by_xid (handlerton *hton, XID *xid) |
| This function is used to rollback one X/Open XA distributed transaction which is in the prepared state. More...
|
|
static int | innobase_set_prepared_in_tc (handlerton *hton, THD *thd) |
| This function is used to write mark an X/Open XA distributed transaction as been prepared in the server transaction coordinator. More...
|
|
static xa_status_code | innobase_set_prepared_in_tc_by_xid (handlerton *hton, XID *xid) |
| Mark an X/Open XA distributed transaction as been prepared in the server transaction coordinator. More...
|
|
static bool | innobase_check_reserved_file_name (handlerton *hton, const char *name) |
| Checks if the file name is reserved in InnoDB. More...
|
|
static bool | innobase_is_valid_tablespace_name (ts_command_type ts_cmd, const char *name) |
| Check tablespace name validity. More...
|
|
static int | innobase_alter_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, const dd::Tablespace *old_ts_def, dd::Tablespace *new_ts_def) |
| This API handles CREATE, ALTER & DROP commands for InnoDB tablespaces. More...
|
|
static const char * | innobase_get_tablespace_filename_ext () |
| Get tablespace datafile name extension. More...
|
|
static void | innodb_space_shutdown () |
| Free tablespace resources. More...
|
|
static int | innodb_shutdown (handlerton *, ha_panic_function) |
| Shut down InnoDB after the Global Data Dictionary has been shut down. More...
|
|
static void | innodb_pre_dd_shutdown (handlerton *) |
| Shut down all InnoDB background tasks that may access the Global Data Dictionary, before the Global Data Dictionary and the rest of InnoDB have been shut down. More...
|
|
static int | innobase_start_trx_and_assign_read_view (handlerton *hton, THD *thd) |
| Creates an InnoDB transaction struct for the thd if it does not yet have one. More...
|
|
static bool | innobase_flush_logs (handlerton *hton, bool binlog_group_flush) |
| Flush InnoDB redo logs to the file system. More...
|
|
static int | innodb_show_status (handlerton *hton, THD *thd, stat_print_fn *stat_print) |
| Implements the SHOW ENGINE INNODB STATUS command. More...
|
|
static bool | innobase_lock_hton_log (handlerton *hton) |
| Implements Log_resource lock. More...
|
|
static bool | innobase_unlock_hton_log (handlerton *hton) |
| Implements Log_resource unlock. More...
|
|
static bool | innobase_collect_hton_log_info (handlerton *hton, Json_dom *json) |
| Implements Log_resource collect_info. More...
|
|
static bool | innobase_show_status (handlerton *hton, THD *thd, stat_print_fn *stat_print, enum ha_stat_type stat_type) |
| Return 0 on success and non-zero on failure. More...
|
|
static void | innodb_enable_monitor_at_startup (char *str) |
| Parse and enable InnoDB monitor counters during server startup. More...
|
|
static void | innobase_fts_store_docid (TABLE *tbl, ulonglong doc_id) |
| Store doc_id value into FTS_DOC_ID field. More...
|
|
static int | innobase_commit_concurrency_validate (THD *, SYS_VAR *, void *save, struct st_mysql_value *value) |
| Check for a valid value of innobase_commit_concurrency. More...
|
|
bool | thd_is_replication_slave_thread (THD *thd) |
| Returns true if the thread is the replication thread on the slave server. More...
|
|
enum durability_properties | thd_requested_durability (const THD *thd) |
| Gets information on the durability property requested by thread. More...
|
|
bool | thd_trx_is_read_only (THD *thd) |
| Returns true if transaction should be flagged as read-only. More...
|
|
THD * | thd_trx_arbitrate (THD *requestor, THD *holder) |
| Check if the transaction can be rolled back. More...
|
|
int | thd_trx_priority (THD *thd) |
|
bool | thd_trx_is_auto_commit (THD *thd) |
| Check if the transaction is an auto-commit transaction. More...
|
|
time_t | thd_start_time (const THD *thd) |
|
std::chrono::system_clock::time_point | thd_start_time (THD *) |
| Get the thread start time. More...
|
|
static dberr_t | innobase_srv_conc_enter_innodb (row_prebuilt_t *prebuilt) |
| Enter InnoDB engine after checking the max number of user threads allowed, else the thread is put into sleep. More...
|
|
static void | innobase_srv_conc_exit_innodb (row_prebuilt_t *prebuilt) |
| Note that the thread wants to leave InnoDB only if it doesn't have any spare tickets. More...
|
|
static void | innobase_srv_conc_force_exit_innodb (trx_t *trx) |
| Force a thread to leave InnoDB even if it has spare tickets. More...
|
|
const char * | server_get_hostname () |
| Returns the NUL terminated value of glob_hostname. More...
|
|
bool | thd_has_edited_nontrans_tables (THD *thd) |
| Returns true if the transaction this thread is processing has edited non-transactional tables. More...
|
|
bool | thd_is_query_block (const THD *thd) |
| Returns true if the thread is executing a SELECT statement. More...
|
|
bool | innobase_should_madvise_buf_pool () |
| Checks sys_vars and determines if allocator should mark large memory segments with MADV_DONTDUMP. More...
|
|
void | innobase_disable_core_dump () |
| Make sure that core file will not be generated, as generating a core file might violate our promise to not dump buffer pool data, and/or might dump not the expected memory pages due to failure in using madvise. More...
|
|
std::chrono::seconds | thd_lock_wait_timeout (THD *thd) |
| Returns the lock wait timeout for the current connection. More...
|
|
void | thd_set_lock_wait_time (THD *thd, std::chrono::steady_clock::duration value) |
| Set the time waited for the lock for the current query. More...
|
|
const char * | thd_innodb_tmpdir (THD *thd) |
| Get the value of innodb_tmpdir. More...
|
|
innodb_session_t *& | thd_to_innodb_session (THD *thd) |
| Obtain the private handler of InnoDB session specific data. More...
|
|
trx_t *& | thd_to_trx (THD *thd) |
| Obtain the InnoDB transaction of a MySQL thread. More...
|
|
ulong | thd_parallel_read_threads (THD *thd) |
| Return the number of read threads for this session. More...
|
|
ulong | thd_ddl_buffer_size (THD *thd) |
| Return the maximum buffer size to use for DDL. More...
|
|
size_t | thd_ddl_threads (THD *thd) noexcept |
|
static bool | thd_is_ins_sel_stmt (THD *user_thd) |
| Check if statement is of type INSERT .... More...
|
|
static void | add_table_to_thread_cache (dict_table_t *table, mem_heap_t *heap, THD *thd) |
| Add the table handler to thread cache. More...
|
|
void | innobase_active_small (void) |
| Increments innobase_active_counter and every INNOBASE_WAKE_INTERVALth time calls srv_active_wake_master_thread. More...
|
|
int | convert_error_code_to_mysql (dberr_t error, uint32_t flags, THD *thd) |
| Converts an InnoDB error code to a MySQL error code. More...
|
|
void | innobase_mysql_print_thd (FILE *f, THD *thd, uint max_query_len) |
| Prints info of a THD object (== user session thread) to the given file. More...
|
|
const char * | innobase_get_err_msg (int error_code) |
| Get the error message format string. More...
|
|
void | innobase_get_cset_width (ulint cset, ulint *mbminlen, ulint *mbmaxlen) |
| Get the variable length bounds of the given character set. More...
|
|
bool | innobase_check_identifier_length (const char *id) |
|
int | innobase_strcasecmp (const char *a, const char *b) |
| Compares NUL-terminated UTF-8 strings case insensitively. More...
|
|
static int | innobase_wildcasecmp (const char *a, const char *b) |
| Compares NUL-terminated UTF-8 strings case insensitively. More...
|
|
const char * | innobase_basename (const char *path_name) |
| Strip dir name from a full path name and return only the file name. More...
|
|
void | innobase_casedn_str (char *a) |
| Makes all characters in a NUL-terminated UTF-8 string lower case. More...
|
|
void | innobase_casedn_path (char *a) |
| Makes all characters in a NUL-terminated UTF-8 path string lower case. More...
|
|
const CHARSET_INFO * | innobase_get_charset (THD *mysql_thd) |
| Determines the connection character set. More...
|
|
const char * | innobase_get_stmt_unsafe (THD *thd, size_t *length) |
| Determines the current SQL statement. More...
|
|
size_t | innobase_get_stmt_safe (THD *thd, char *buf, size_t buflen) |
| Determines the current SQL statement. More...
|
|
ulint | innobase_get_table_cache_size (void) |
| Get the current setting of the table_def_size global parameter. More...
|
|
ulint | innobase_get_lower_case_table_names (void) |
| Get the current setting of the lower_case_table_names global parameter from mysqld.cc. More...
|
|
char * | innobase_mysql_tmpdir () |
| return any of the tmpdir path More...
|
|
os_fd_t | innobase_mysql_tmpfile (const char *path) |
| Creates a temporary file in the location specified by the parameter path. More...
|
|
static ulint | innobase_convert_string (void *to, ulint to_length, const CHARSET_INFO *to_cs, const void *from, ulint from_length, const CHARSET_INFO *from_cs, uint *errors) |
| Wrapper around MySQL's copy_and_convert function. More...
|
|
ulint | innobase_raw_format (const char *data, ulint data_len, ulint charset_coll, char *buf, ulint buf_size) |
| Formats the raw data in "data" (in InnoDB on-disk format) that is of type DATA_(CHAR|VARCHAR|MYSQL|VARMYSQL) using "charset_coll" and writes the result to "buf". More...
|
|
ulonglong | innobase_next_autoinc (ulonglong current, ulonglong need, ulonglong step, ulonglong offset, ulonglong max_value) |
| Compute the next autoinc value. More...
|
|
static void | innobase_trx_init (THD *thd, trx_t *trx) |
| Initializes some fields in an InnoDB transaction object. More...
|
|
trx_t * | innobase_trx_allocate (THD *thd) |
| Allocates an InnoDB transaction for a MySQL handler object for DML. More...
|
|
trx_t * | check_trx_exists (THD *thd) |
| Gets the InnoDB transaction handle for a MySQL handler object, creates an InnoDB transaction struct if the corresponding MySQL thread struct still lacks one. More...
|
|
static void | innodb_replace_trx_in_thd (THD *thd, void *new_trx_arg, void **ptr_trx_arg) |
| InnoDB transaction object that is currently associated with THD is replaced with that of the 2nd argument. More...
|
|
static void | trx_register_for_2pc (trx_t *trx) |
| Note that a transaction has been registered with MySQL 2PC coordinator. More...
|
|
static void | innobase_copy_frm_flags_from_create_info (dict_table_t *innodb_table, const HA_CREATE_INFO *create_info) |
| Copy table flags from MySQL's HA_CREATE_INFO into an InnoDB table object. More...
|
|
void | innobase_copy_frm_flags_from_table_share (dict_table_t *innodb_table, const TABLE_SHARE *table_share) |
| Copy table flags from MySQL's TABLE_SHARE into an InnoDB table object. More...
|
|
void | innobase_register_trx (handlerton *hton, THD *thd, trx_t *trx) |
| Registers an InnoDB transaction with the MySQL 2PC coordinator, so that the MySQL XA code knows to call the InnoDB prepare and commit, or rollback for the transaction. More...
|
|
void | innobase_quote_identifier (FILE *file, trx_t *trx, const char *id) |
| Quote a standard SQL identifier like tablespace, index or column name. More...
|
|
static char * | innobase_convert_identifier (char *buf, ulint buflen, const char *id, ulint idlen, THD *thd) |
| Convert a table name to the MySQL system_charset_info (UTF-8) and quote it. More...
|
|
char * | innobase_convert_name (char *buf, ulint buflen, const char *id, ulint idlen, THD *thd) |
| Convert a table name to the MySQL system_charset_info (UTF-8). More...
|
|
void | innobase_format_name (char *buf, ulint buflen, const char *name) |
| A wrapper function of innobase_convert_name(), convert a table name to the MySQL system_charset_info (UTF-8) and quote it if needed. More...
|
|
bool | trx_is_interrupted (const trx_t *trx) |
| Determines if the currently running transaction has been interrupted. More...
|
|
bool | trx_is_strict (trx_t *trx) |
| Determines if the currently running transaction is in strict mode. More...
|
|
static int | innodb_init_abort () |
| Free any resources that were allocated and return failure. More...
|
|
static int | innobase_init_files (dict_init_mode_t dict_init_mode, List< const Plugin_tablespace > *tablespaces) |
| Open or create InnoDB data files. More...
|
|
static bool | innobase_ddse_dict_init (dict_init_mode_t dict_init_mode, uint version, List< const dd::Object_table > *tables, List< const Plugin_tablespace > *tablespaces) |
| Initialize InnoDB for being used to store the DD tables. More...
|
|
bool | apply_dd_undo_state (space_id_t space_id, const dd::Tablespace *dd_space) |
| Save the state of undo tablespaces from the dd to the undo::Tablespace. More...
|
|
static void | innobase_dict_register_dd_table_id (dd::Object_id dd_table_id) |
| Initialize the set of hard coded DD table ids. More...
|
|
static bool | boot_tablespaces (THD *thd) |
| Discover all InnoDB tablespaces. More...
|
|
static bool | predefine_tablespace (dd::cache::Dictionary_client *dd_client, space_id_t space_id, uint32_t flags, const char *name, const char *filename) |
| Create metadata for a predefined tablespace at server initialization. More...
|
|
static bool | innobase_is_dict_readonly () |
| Check if InnoDB is in a mode where the data dictionary is read-only. More...
|
|
static bool | update_innodb_temporary_metadata (THD *thd) |
| Update metadata for innodb_temporary tablespace at server startup. More...
|
|
static bool | predefine_undo_tablespaces (dd::cache::Dictionary_client *dd_client) |
| Predefine the undo tablespace metadata at server initialization. More...
|
|
static void | innobase_dict_cache_reset (const char *schema_name, const char *table_name) |
| Invalidate an entry or entries for partitioned table from the dict cache. More...
|
|
static void | innobase_dict_cache_reset_tables_and_tablespaces () |
| Invalidate user table dict cache after Replication Plugin recovers. More...
|
|
static bool | innobase_dict_recover (dict_recovery_mode_t dict_recovery_mode, uint version) |
| Perform high-level recovery in InnoDB as part of initializing the data dictionary. More...
|
|
static void | innobase_post_recover () |
| DDL crash recovery: process the records recovered from "log_ddl" table. More...
|
|
static bool | innobase_dict_get_server_version (uint *version) |
| Get the server version id stored in the header of the dictionary tablespace. More...
|
|
static bool | innobase_dict_set_server_version () |
| Store the current server version number into the header of the dictionary tablespace. More...
|
|
static int | innobase_page_track_start (uint64_t *start_id) |
| Start page tracking. More...
|
|
static int | innobase_page_track_stop (uint64_t *stop_id) |
| Stop page tracking. More...
|
|
static int | innobase_page_track_purge (uint64_t *purge_id) |
| Purge page tracking data. More...
|
|
static int | innobase_page_track_get_page_ids (Page_Track_Callback cbk_func, void *cbk_ctx, uint64_t *start_id, uint64_t *stop_id, unsigned char *buffer, size_t buffer_len) |
| Fetch tracked pages. More...
|
|
static int | innobase_page_track_get_num_page_ids (uint64_t *start_id, uint64_t *stop_id, uint64_t *num_pages) |
| Fetch approximate number of tracked pages in the given range. More...
|
|
static void | innobase_page_track_get_status (std::vector< std::pair< lsn_t, bool > > &status) |
| Fetch the page tracking status. More...
|
|
static bool | innobase_is_supported_system_table (const char *, const char *, bool is_sql_layer_system_table) |
| This function checks if the given db.tablename is a system table supported by Innodb and is used as an initializer for the data member is_supported_system_table of InnoDB storage engine handlerton. More...
|
|
bool | innobase_encryption_key_rotation () |
| Rotate the encrypted tablespace keys according to master key rotation. More...
|
|
static bool | innobase_redo_set_state (THD *thd, bool enable) |
| Enable or Disable SE write ahead logging. More...
|
|
static uint | innobase_partition_flags () |
| Return partitioning flags. More...
|
|
static void | innodb_log_checksums_func_update (bool check) |
| Update log_checksum_algorithm_ptr with a pointer to the function corresponding to whether checksums are enabled. More...
|
|
static void | innodb_undo_tablespaces_deprecate () |
| Validate innodb_undo_tablespaces. More...
|
|
template<size_t N> |
static bool | innodb_variable_is_set (const char(&var_name)[N]) |
|
static bool | innodb_redo_log_capacity_is_set () |
|
bool | innodb_log_file_size_is_set () |
|
bool | innodb_log_n_files_is_set () |
|
static bool | innodb_buffer_pool_instances_is_set () |
|
static bool | innodb_page_cleaners_is_set () |
|
static bool | innodb_io_capacity_max_is_set () |
|
static bool | innodb_flush_method_is_set () |
|
static void | innodb_buffer_pool_size_init () |
| Initialize and normalize innodb_buffer_pool_size. More...
|
|
static void | innodb_redo_log_capacity_update_default (ulonglong new_def) |
| Update the mysql_sysvar_redo_log_capacity's default value. More...
|
|
static void | innodb_redo_log_capacity_init () |
| Initialize srv_redo_log_capacity / srv_redo_log_capacity_used. More...
|
|
static void | innodb_io_capacity_max_update_default (ulong new_def) |
| Update the mysql_sysvar_io_capacity_max's default value. More...
|
|
static int | innodb_init_params () |
| Initialize, validate and normalize the InnoDB startup parameters. More...
|
|
long | innobase_get_open_files_limit () |
| Returns current value of the "innodb_open_files" configuration variable. More...
|
|
void | innobase_set_open_files_limit (long new_limit) |
| Sets new value of the "innodb_open_files" configuration variable to present to users. More...
|
|
template<typename T > |
static void | get_metric_simple_integer (void *measurement_context, measurement_delivery_callback_t delivery, void *delivery_context) |
|
template<typename T > |
constexpr PSI_metric_info_v1 | simple (const char *name, const char *unit, const char *description, MetricOTELType type, T &variable) |
|
static int | innodb_init (void *p) |
| Initialize the InnoDB storage engine plugin. More...
|
|
static int | innodb_deinit (MYSQL_PLUGIN plugin_info) |
| De initialize the InnoDB storage engine plugin. More...
|
|
static bool | dd_create_hardcoded (space_id_t space_id, const char *filename) |
| Create a hard-coded tablespace file at server initialization. More...
|
|
static bool | dd_open_hardcoded (space_id_t space_id, const char *filename) |
| Open a hard-coded tablespace file at server initialization. More...
|
|
void | innobase_commit_low (trx_t *trx) |
| Commits a transaction in an InnoDB database. More...
|
|
static int | innobase_rollback_trx (trx_t *trx) |
| Rolls back a transaction. More...
|
|
static bool | write_delete_schema_directory_log (handlerton *hton, const char *schema_name, const bool is_drop_schema) |
| Writes DELETE_SCHEMA_DIRECTORY_LOG. More...
|
|
static uint32_t | get_zip_shift_size (ulint key_block_size) |
| ** InnoDB database tables More...
|
|
static void | test_normalize_table_name () |
|
static void | test_ut_format_name () |
|
bool | innobase_match_index_columns (const KEY *key_info, const dict_index_t *index_info) |
| Match index columns between MySQL and InnoDB. More...
|
|
static void | innobase_vcol_build_templ (const TABLE *table, const dict_index_t *clust_index, Field *field, const dict_col_t *col, mysql_row_templ_t *templ, ulint col_no) |
| Build a template for a base column for a virtual column. More...
|
|
void | innobase_build_v_templ_callback (const TABLE *table, void *ib_table) |
| Callback used by MySQL server layer to initialize the table virtual columns' template. More...
|
|
void | innobase_build_v_templ (const TABLE *table, const dict_table_t *ib_table, dict_vcol_templ_t *s_templ, const dict_add_v_col_t *add_v, bool locked, const char *share_tbl_name) |
| Build template for the virtual columns and their base columns. More...
|
|
static bool | innobase_build_index_translation (const TABLE *table, dict_table_t *ib_table, INNOBASE_SHARE *share) |
| This function builds a translation table in INNOBASE_SHARE structure for fast index location with mysql array number from its table->key_info structure. More...
|
|
static dict_index_t * | innobase_index_lookup (INNOBASE_SHARE *share, uint keynr) |
| This function uses index translation table to quickly locate the requested index structure. More...
|
|
int | innobase_fts_text_cmp (const void *cs, const void *p1, const void *p2) |
| Compare two character string according to their charset. More...
|
|
int | innobase_fts_nocase_compare (const CHARSET_INFO *cs, const fts_string_t *s1, const fts_string_t *s2) |
| Compare two FTS character strings case insensitively according to their charset. More...
|
|
int | innobase_nocase_compare (const void *cs, const char *s1, const char *s2) |
| Compare two character strings case insensitively according to their charset. More...
|
|
ulint | innobase_strnxfrm (const CHARSET_INFO *cs, const uchar *str, const ulint len) |
| Get the first character's code position for FTS index partition. More...
|
|
int | innobase_fts_text_cmp_prefix (const void *cs, const void *p1, const void *p2) |
| Compare two character string according to their charset. More...
|
|
size_t | innobase_fts_casedn_str (CHARSET_INFO *cs, char *src, size_t src_len, char *dst, size_t dst_len) |
| Makes all characters in a string lower case. More...
|
|
bool | true_word_char (int c, uint8_t ch) |
|
ulint | innobase_mysql_fts_get_token (CHARSET_INFO *cs, const byte *start, const byte *end, fts_string_t *token) |
| Get the next token from the given string and store it in *token. More...
|
|
ulint | get_innobase_type_from_mysql_type (ulint *unsigned_flag, const void *f) |
| Converts a MySQL type to an InnoDB type. More...
|
|
ulint | get_innobase_type_from_mysql_dd_type (ulint *unsigned_flag, ulint *binary_type, ulint *charset_no, dd::enum_column_types dd_type, const CHARSET_INFO *field_charset, bool is_unsigned) |
| Converts a MySQL data-dictionary type to an InnoDB type. More...
|
|
static uint | innobase_read_from_2_little_endian (const uchar *buf) |
| Reads an unsigned integer value < 64k from 2 bytes, in the little-endian storage format. More...
|
|
static const Field * | build_template_needs_field (bool index_contains, bool read_just_key, bool fetch_all_in_key, bool fetch_primary_key_cols, dict_index_t *index, const TABLE *table, ulint i, ulint num_v) |
| Determines if a field is needed in a m_prebuilt struct 'template'. More...
|
|
bool | build_template_needs_field_in_icp (const dict_index_t *index, const row_prebuilt_t *prebuilt, bool contains, ulint i, bool is_virtual) |
| Determines if a field is needed in a m_prebuilt struct 'template'. More...
|
|
static mysql_row_templ_t * | build_template_field (row_prebuilt_t *prebuilt, dict_index_t *clust_index, dict_index_t *index, TABLE *table, const Field *field, ulint i, ulint v_no) |
| Adds a field to a m_prebuilt struct 'template'. More...
|
|
static void | set_templ_icp (mysql_row_templ_t *templ, const dict_index_t *index, const dict_index_t *scan_index, ulint col_position) |
| Set Index Condition Push down (ICP) field number in template. More...
|
|
static void | innobase_store_multi_value_low (json_binary::Value *bv, multi_value_data **valuep, Field_typed_array *fld, dfield_t *dfield, ulint comp, mem_heap_t *heap) |
| Parse out multi-value and store in a multi_value_data struct. More...
|
|
static bool | innobase_store_multi_value (json_binary::Value &v, multi_value_data *value, Field_typed_array *fld, dfield_t *dfield, bool comp, mem_heap_t *heap) |
| Handle the multi-value array, parse the values and store them. More...
|
|
void | innobase_get_multi_value (const TABLE *mysql_table, ulint f_idx, dfield_t *dfield, multi_value_data *value, uint old_val, ulint comp, mem_heap_t *heap) |
| Parse out multi-values from a MySQL record. More...
|
|
static byte * | innodb_fill_old_vcol_val (row_prebuilt_t *prebuilt, dfield_t *vfield, ulint o_len, const byte *old_mysql_row_col, ulint col_pack_len, byte *buf) |
| Fill the update vector's "old_vrow" field for those non-updated, but indexed columns. More...
|
|
static void | innobase_get_multi_value_and_diff (const TABLE *mysql_table, ulint field_idx, dfield_t *old_field, dfield_t *new_field, uint old_value, ulint comp, mem_heap_t *heap) |
| Parse out multi-values from both old and new MySQL records, at the meantime, calculate the difference between two records. More...
|
|
static dberr_t | calc_row_difference (upd_t *uvect, const uchar *old_row, uchar *new_row, TABLE *table, uchar *upd_buff, ulint buff_len, row_prebuilt_t *prebuilt, THD *thd) |
| Checks which fields have changed in a row and stores information of them to an update vector. More...
|
|
page_cur_mode_t | convert_search_mode_to_innobase (ha_rkey_function find_flag) |
| Converts a search mode flag understood by MySQL to a flag understood by InnoDB. More...
|
|
static void | innobase_fts_create_doc_id_key (dtuple_t *tuple, const dict_index_t *index, doc_id_t *doc_id) |
| Set up search tuple for a query through FTS_DOC_ID_INDEX on supplied Doc ID. More...
|
|
void | innodb_base_col_setup (dict_table_t *table, const Field *field, dict_v_col_t *v_col) |
| Set up base columns for virtual column. More...
|
|
void | innodb_base_col_setup_for_stored (const dict_table_t *table, const Field *field, dict_s_col_t *s_col) |
| Set up base columns for stored column. More...
|
|
template<typename Index > |
const dd::Index * | get_my_dd_index (const Index *index) |
|
template<> |
const dd::Index * | get_my_dd_index< dd::Index > (const dd::Index *dd_index) |
|
template<> |
const dd::Index * | get_my_dd_index< dd::Partition_index > (const dd::Partition_index *dd_index) |
|
int | create_index (trx_t *trx, const TABLE *form, uint32_t flags, const char *table_name, uint key_num, const dd::Table *dd_table) |
| Creates an index in an InnoDB database. More...
|
|
int | create_clustered_index_when_no_primary (trx_t *trx, uint32_t flags, const char *table_name) |
| Creates an index to an InnoDB table when the user has defined no primary index. More...
|
|
static int | validate_tablespace_name (ts_command_type ts_command, const char *name) |
| Validate the tablespace name provided for a tablespace DDL. More...
|
|
bool | innobase_fts_load_stopword (dict_table_t *table, trx_t *trx, THD *thd) |
| Initialize the table FTS stopword list. More...
|
|
static ulint | innobase_parse_merge_threshold (THD *thd, const char *str) |
| Parse MERGE_THRESHOLD value from the string. More...
|
|
void | innobase_parse_hint_from_comment (THD *thd, dict_table_t *table, const TABLE_SHARE *table_share) |
| Parse hint for table and its indexes, and update the information in dictionary. More...
|
|
static bool | innobase_is_base_s_col (const TABLE *table, const char *name) |
| Check a column (name) is a base column for any stored column in the table. More...
|
|
static dberr_t | innobase_check_fk_base_col (const dd::Table *dd_table, const TABLE *table) |
| Check any cascading foreign key columns are base columns for any stored columns in the table. More...
|
|
template int | create_table_info_t::create_table_update_global_dd< dd::Table > (dd::Table *) |
|
template int | create_table_info_t::create_table_update_global_dd< dd::Partition > (dd::Partition *) |
|
template int | innobase_basic_ddl::create_impl< dd::Table > (THD *, const char *, TABLE *, HA_CREATE_INFO *, dd::Table *, bool, bool, bool, uint32_t, uint32_t, const dd::Table *) |
|
template int | innobase_basic_ddl::create_impl< dd::Partition > (THD *, const char *, TABLE *, HA_CREATE_INFO *, dd::Partition *, bool, bool, bool, uint32_t, uint32_t, const dd::Table *) |
|
template int | innobase_basic_ddl::delete_impl< dd::Table > (THD *, const char *, const dd::Table *, const TABLE *) |
|
template int | innobase_basic_ddl::delete_impl< dd::Partition > (THD *, const char *, const dd::Partition *, const TABLE *) |
|
template int | innobase_basic_ddl::rename_impl< dd::Table > (THD *, const char *, const char *, const dd::Table *, const dd::Table *, const TABLE *) |
|
template int | innobase_basic_ddl::rename_impl< dd::Partition > (THD *, const char *, const char *, const dd::Partition *, const dd::Partition *, const TABLE *) |
|
static bool | dd_is_only_column (const dd::Index *index, const dd::Column *column) |
| Check if a column is the only column in an index. More...
|
|
static int | validate_create_tablespace_info (ib_file_suffix type, st_alter_tablespace *alter_info) |
| Validate the parameters in st_alter_tablespace before using them in InnoDB tablespace functions. More...
|
|
static int | innodb_create_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, dd::Tablespace *dd_space) |
| CREATE a tablespace. More...
|
|
static int | innobase_alter_autoextend_size_tablespace (handlerton *hton, st_alter_tablespace *alter_info, const dd::Tablespace *old_dd_space) |
| Alter AUTOEXTEND_SIZE a tablespace. More...
|
|
static int | innobase_alter_encrypt_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, const dd::Tablespace *old_dd_space, dd::Tablespace *new_dd_space) |
| Alter Encrypt/Unencrypt a tablespace. More...
|
|
static int | innodb_alter_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, const dd::Tablespace *old_dd_space, dd::Tablespace *new_dd_space) |
| ALTER an undo tablespace. More...
|
|
static int | innodb_drop_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, const dd::Tablespace *dd_space) |
| DROP a tablespace. More...
|
|
static int | innodb_create_undo_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, dd::Tablespace *dd_space) |
| CREATE an undo tablespace. More...
|
|
static int | innodb_alter_undo_tablespace_active (undo::Tablespace *undo_space, dd::String_type dd_state, dd::Tablespace *dd_space) |
| ALTER an undo tablespace to ACTIVE. More...
|
|
static int | innodb_alter_undo_tablespace_inactive (undo::Tablespace *undo_space, dd::String_type dd_state, dd::Tablespace *dd_space) |
| ALTER an undo tablespace to INACTIVE. More...
|
|
static int | innodb_alter_undo_tablespace (handlerton *hton, st_alter_tablespace *alter_info, dd::Tablespace *dd_space) |
| ALTER an undo tablespace. More...
|
|
static int | innodb_drop_undo_tablespace (handlerton *hton, THD *thd, st_alter_tablespace *alter_info, const dd::Tablespace *dd_space) |
| DROP an undo tablespace. More...
|
|
void | innodb_set_buf_pool_size (long long buf_pool_size) |
| Update the system variable with the given value of the InnoDB buffer pool size. More...
|
|
static int | innobase_get_mysql_key_number_for_index (INNOBASE_SHARE *share, const TABLE *table, dict_table_t *ib_table, const dict_index_t *index) |
| Calculates the key number used inside MySQL for an Innobase index. More...
|
|
rec_per_key_t | innodb_rec_per_key (const dict_index_t *index, ulint i, ha_rows records) |
| Calculate Record Per Key value. More...
|
|
static ulonglong | innobase_peek_autoinc (dict_table_t *innodb_table, bool print_note) |
| Read the auto_increment counter of a table, using the AUTOINC lock irrespective of innodb_autoinc_lock_mode. More...
|
|
static void | calculate_delete_length_stat (const dict_table_t *ib_table, ha_statistics *stats, THD *thd) |
| Calculate delete length statistic. More...
|
|
static void | calculate_index_size_stats (const dict_table_t *ib_table, uint64_t n_rows, ulint stat_clustered_index_size, ulint stat_sum_of_other_index_sizes, ha_statistics *stats) |
| Calculate stats based on index size. More...
|
|
double | index_pct_cached (const dict_index_t *index) |
| Estimate what percentage of an index's pages are cached in the buffer pool. More...
|
|
static uint64_t | innodb_get_auto_increment_for_uncached (dd::Object_id se_private_id, const dd::Properties &tbl_se_private_data) |
| Get the autoincrement for the given table id which is not in the cache. More...
|
|
static bool | innodb_get_table_statistics_for_uncached (const char *db_name, const char *tbl_name, const char *norm_name, dd::Object_id se_private_id, const dd::Properties &ts_se_private_data, const dd::Properties &tbl_se_private_data, ulint stat_flags, ha_statistics *stats) |
| Retrieves table statistics only for uncache table only. More...
|
|
trx_t::isolation_level_t | innobase_trx_map_isolation_level (enum_tx_isolation iso) |
| Maps a MySQL trx isolation level code to the InnoDB isolation level code. More...
|
|
static void | innodb_export_status () |
| Here we export InnoDB status variables to MySQL. More...
|
|
static int | innodb_show_mutex_status (handlerton *hton, THD *thd, stat_print_fn *stat_print) |
| Implements the SHOW MUTEX STATUS command, for mutexes. More...
|
|
static int | innodb_show_rwlock_status (handlerton *hton, THD *thd, stat_print_fn *stat_print) |
| Implements the SHOW MUTEX STATUS command. More...
|
|
static int | innodb_show_latch_status (handlerton *hton, THD *thd, stat_print_fn *stat_print) |
| Implements the SHOW MUTEX STATUS command. More...
|
|
ulint | innobase_get_at_most_n_mbchars (ulint charset_id, ulint prefix_len, ulint data_len, const char *str) |
| This function is used to find the storage length in bytes of the first n characters for prefix indexes using a multibyte character set. More...
|
|
static void | innodb_io_capacity_max_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_io_capacity_max using the "saved" value. More...
|
|
static void | innodb_io_capacity_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_io_capacity using the "saved" value. More...
|
|
static void | innodb_max_dirty_pages_pct_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_max_dirty_pages_pct using the "saved" value. More...
|
|
static void | innodb_max_dirty_pages_pct_lwm_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_max_dirty_pages_pct_lwm using the "saved" value. More...
|
|
static int | check_func_bool (THD *, SYS_VAR *, void *save, st_mysql_value *value) |
| Utility method that checks if user provided valid value. More...
|
|
static int | check_session_admin (THD *thd) |
| Utility method that checks if user has correct session administrative dynamic privileges. More...
|
|
static void | innodb_srv_buffer_pool_in_core_file_update (THD *, SYS_VAR *, void *, const void *save) |
|
static bool | innodb_buffer_pool_size_validate (THD *thd, longlong buffer_pool_size, ulint &aligned_buffer_pool_size) |
| Validate the requested buffer pool size. More...
|
|
static void | innodb_extend_and_initialize_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Set the variable tbsp_extend_and_initialize. More...
|
|
static void | innodb_buffer_pool_size_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Update the system variable innodb_buffer_pool_size using the "saved" value. More...
|
|
static void | innobase_deadlock_detect_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innobase_deadlock_detect using the "saved" value. More...
|
|
static int | innodb_internal_table_validate (THD *thd, SYS_VAR *, void *save, struct st_mysql_value *value) |
| Check whether valid argument given to "innodb_fts_internal_tbl_name" This function is registered as a callback with MySQL. More...
|
|
static void | innodb_adaptive_hash_index_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_adaptive_hash_index using the "saved" value. More...
|
|
static void | innodb_cmp_per_index_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_cmp_per_index using the "saved" value. More...
|
|
static void | innodb_old_blocks_pct_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_old_blocks_pct using the "saved" value. More...
|
|
static void | innodb_change_buffer_max_size_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_old_blocks_pct using the "saved" value. More...
|
|
static void | innodb_save_page_no (THD *, SYS_VAR *, void *, const void *save) |
| Save an InnoDB page number. More...
|
|
static void | innodb_make_page_dirty (THD *, SYS_VAR *, void *, const void *save) |
| Make the first page of given user tablespace dirty. More...
|
|
static void | innodb_monitor_set_option (const monitor_info_t *monitor_info, mon_option_t set_option) |
| Update the monitor counter according to the "set_option", turn on/off or reset specified monitor counter. More...
|
|
static void | innodb_monitor_update_wildcard (const char *name, mon_option_t set_option) |
| Find matching InnoDB monitor counters and update their status according to the "set_option", turn on/off or reset specified monitor counter. More...
|
|
static ulint | innodb_monitor_id_by_name_get (const char *name) |
| Given a configuration variable name, find corresponding monitor counter and return its monitor ID if found. More...
|
|
static bool | innodb_monitor_validate_wildcard_name (const char *name) |
| Validate that the passed in monitor name matches at least one monitor counter name with wildcard compare. More...
|
|
static int | innodb_monitor_valid_byname (void *save, const char *name) |
| Validate the passed in monitor name, find and save the corresponding monitor name in the function parameter "save". More...
|
|
static int | innodb_monitor_validate (THD *, SYS_VAR *, void *save, struct st_mysql_value *value) |
| Validate passed-in "value" is a valid monitor counter name. More...
|
|
static void | innodb_monitor_update (THD *thd, void *var_ptr, const void *save, mon_option_t set_option, bool free_mem) |
| Update the system variable innodb_enable(disable/reset/reset_all)_monitor according to the "set_option" and turn on/off or reset specified monitor counter. More...
|
|
static int | innodb_srv_buf_dump_filename_validate (THD *thd, SYS_VAR *, void *save, struct st_mysql_value *value) |
| Validate if passed-in "value" is a valid value for innodb_buffer_pool_filename. More...
|
|
static bool | innodb_buffer_pool_evict_uncompressed (void) |
| Evict all uncompressed pages of compressed tables from the buffer pool. More...
|
|
static void | innodb_buffer_pool_evict_update (THD *, SYS_VAR *, void *, const void *save) |
| Called on SET GLOBAL innodb_buffer_pool_evict=... Handles some values specially, to evict pages from the buffer pool. More...
|
|
static void | innodb_enable_monitor_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Update the system variable innodb_monitor_enable and enable specified monitor counter. More...
|
|
static void | innodb_disable_monitor_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Update the system variable innodb_monitor_disable and turn off specified monitor counter. More...
|
|
static void | innodb_reset_monitor_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Update the system variable innodb_monitor_reset and reset specified monitor counter(s). More...
|
|
static void | innodb_reset_all_monitor_update (THD *thd, SYS_VAR *, void *var_ptr, const void *save) |
| Update the system variable innodb_monitor_reset_all and reset all value related monitor counter. More...
|
|
static void | innodb_undo_tablespaces_update (THD *thd, SYS_VAR *var, void *var_ptr, const void *save) |
| Validate the value of innodb_undo_tablespaces global variable. More...
|
|
static int | validate_innodb_undo_log_encrypt (THD *thd, SYS_VAR *var, void *save, struct st_mysql_value *value) |
| Validate the value of innodb_undo_log_encrypt global variable. More...
|
|
static int | validate_innodb_redo_log_encrypt (THD *thd, SYS_VAR *var, void *save, struct st_mysql_value *value) |
| Validate the value of innodb_redo_log_encrypt global variable. More...
|
|
static void | innodb_rollback_segments_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the number of rollback segments per tablespace when the system variable innodb_rollback_segments is changed. More...
|
|
static int | show_innodb_vars (THD *, SHOW_VAR *var, char *) |
| Callback function for accessing the InnoDB variables from MySQL: SHOW VARIABLES. More...
|
|
bool | innobase_index_name_is_reserved (THD *thd, const KEY *key_info, ulint num_of_keys) |
| This function checks each index name for a table against reserved system default primary index name 'GEN_CLUST_INDEX'. More...
|
|
static void | wait_background_drop_list_empty (THD *, SYS_VAR *, void *, const void *) |
| Wait for the background drop list to become empty. More...
|
|
static void | purge_run_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Set the purge state to RUN. More...
|
|
static void | purge_stop_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Set the purge state to STOP. More...
|
|
static void | log_flush_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Force InnoDB to flush redo log up to current_lsn. More...
|
|
static void | checkpoint_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Force InnoDB to do sharp checkpoint. More...
|
|
static void | checkpoint_fuzzy_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Force InnoDB to do fuzzy checkpoint. More...
|
|
static void | checkpoint_disabled_update (THD *, SYS_VAR *, void *, const void *save) |
| Updates srv_checkpoint_disabled - allowing or disallowing checkpoints. More...
|
|
static void | buf_flush_list_now_set (THD *, SYS_VAR *, void *, const void *save) |
| Force a dirty pages flush now. More...
|
|
static void | innodb_merge_threshold_set_all_debug_update (THD *, SYS_VAR *, void *, const void *save) |
| Override current MERGE_THRESHOLD setting for all indexes at dictionary now. More...
|
|
static void | buffer_pool_dump_now (THD *, SYS_VAR *, void *, const void *save) |
| Trigger a dump of the buffer pool if innodb_buffer_pool_dump_now is set to ON. More...
|
|
static void | buffer_pool_load_now (THD *, SYS_VAR *, void *, const void *save) |
| Trigger a load of the buffer pool if innodb_buffer_pool_load_now is set to ON. More...
|
|
static void | buffer_pool_load_abort (THD *, SYS_VAR *, void *, const void *save) |
| Abort a load of the buffer pool if innodb_buffer_pool_load_abort is set to ON. More...
|
|
static void | innodb_log_write_ahead_size_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_log_write_ahead_size using the "saved" value. More...
|
|
static void | innodb_log_buffer_size_update (THD *, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_log_buffer_size using the "saved" value. More...
|
|
static void | innodb_log_writer_threads_update (THD *, SYS_VAR *, void *var_ptr, const void *save) |
| Update the innodb_log_writer_threads parameter. More...
|
|
static void | innodb_redo_log_capacity_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_redo_log_capacity using the "saved" value. More...
|
|
static void | innodb_thread_concurrency_update (THD *thd, SYS_VAR *, void *, const void *save) |
| Update the system variable innodb_thread_concurrency using the "saved" value. More...
|
|
static void | innodb_log_checksums_update (THD *, SYS_VAR *, void *var_ptr, const void *save) |
| Update the innodb_log_checksums parameter. More...
|
|
static | MYSQL_SYSVAR_ENUM (checksum_algorithm, srv_checksum_algorithm, PLUGIN_VAR_RQCMDARG, "The algorithm InnoDB uses for page checksumming. Possible values are" " CRC32 (hardware accelerated if the CPU supports it)" " write crc32, allow any of the other checksums to match when reading;" " STRICT_CRC32" " write crc32, do not allow other algorithms to match when reading;" " INNODB" " write a software calculated checksum, allow any other checksums" " to match when reading;" " STRICT_INNODB" " write a software calculated checksum, do not allow other algorithms" " to match when reading;" " NONE" " write a constant magic number, do not do any checksum verification" " when reading;" " STRICT_NONE" " write a constant magic number, do not allow values other than that" " magic number when reading;" " Files updated when this option is set to crc32 or strict_crc32 will" " not be readable by MySQL versions older than 5.6.3", nullptr, nullptr, SRV_CHECKSUM_ALGORITHM_CRC32, &innodb_checksum_algorithm_typelib) |
|
static | MYSQL_SYSVAR_BOOL (log_checksums, srv_log_checksums, PLUGIN_VAR_RQCMDARG, "Whether to compute and require checksums for InnoDB redo log blocks", nullptr, innodb_log_checksums_update, true) |
|
static | MYSQL_SYSVAR_STR (data_home_dir, innobase_data_home_dir, PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "The common part for InnoDB table spaces.", nullptr, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_BOOL (stats_include_delete_marked, srv_stats_include_delete_marked, PLUGIN_VAR_OPCMDARG, "Include delete marked records when calculating persistent statistics", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (io_capacity, srv_io_capacity, PLUGIN_VAR_RQCMDARG, "Number of IOPs the server can do. Tunes the background IO rate", nullptr, innodb_io_capacity_update, 10000, 100, SRV_MAX_IO_CAPACITY_LIMIT, 0) |
|
static | MYSQL_SYSVAR_ULONG (io_capacity_max, srv_max_io_capacity, PLUGIN_VAR_RQCMDARG, "Limit to which innodb_io_capacity can be inflated.", nullptr, innodb_io_capacity_max_update, SRV_MAX_IO_CAPACITY_DUMMY_DEFAULT, 100, SRV_MAX_IO_CAPACITY_LIMIT, 0) |
|
static | MYSQL_SYSVAR_BOOL (background_drop_list_empty, innodb_background_drop_list_empty, PLUGIN_VAR_OPCMDARG, "Wait for the background drop list to become empty", nullptr, wait_background_drop_list_empty, false) |
|
static | MYSQL_SYSVAR_BOOL (purge_run_now, innodb_purge_run_now, PLUGIN_VAR_OPCMDARG, "Set purge state to RUN", nullptr, purge_run_now_set, false) |
|
static | MYSQL_SYSVAR_BOOL (purge_stop_now, innodb_purge_stop_now, PLUGIN_VAR_OPCMDARG, "Set purge state to STOP", nullptr, purge_stop_now_set, false) |
|
static | MYSQL_SYSVAR_BOOL (log_flush_now, innodb_log_flush_now, PLUGIN_VAR_OPCMDARG, "Force flush of redo up to current lsn", nullptr, log_flush_now_set, false) |
|
static | MYSQL_SYSVAR_BOOL (log_checkpoint_now, innodb_log_checkpoint_now, PLUGIN_VAR_OPCMDARG, "Force sharp checkpoint now", nullptr, checkpoint_now_set, false) |
|
static | MYSQL_SYSVAR_BOOL (log_checkpoint_fuzzy_now, innodb_log_checkpoint_fuzzy_now, PLUGIN_VAR_OPCMDARG, "Force fuzzy checkpoint now", nullptr, checkpoint_fuzzy_now_set, false) |
|
static | MYSQL_SYSVAR_BOOL (checkpoint_disabled, srv_checkpoint_disabled, PLUGIN_VAR_OPCMDARG, "Disable checkpoints", nullptr, checkpoint_disabled_update, false) |
|
static | MYSQL_SYSVAR_BOOL (buf_flush_list_now, innodb_buf_flush_list_now, PLUGIN_VAR_OPCMDARG, "Force dirty page flush now", nullptr, buf_flush_list_now_set, false) |
|
static | MYSQL_SYSVAR_UINT (merge_threshold_set_all_debug, innodb_merge_threshold_set_all_debug, PLUGIN_VAR_RQCMDARG, "Override current MERGE_THRESHOLD setting for all indexes at dictionary" " cache by the specified value dynamically, at the time.", nullptr, innodb_merge_threshold_set_all_debug_update, DICT_INDEX_MERGE_THRESHOLD_DEFAULT, 1, 50, 0) |
|
static | MYSQL_SYSVAR_ULONG (semaphore_wait_timeout_debug, srv_fatal_semaphore_wait_threshold, PLUGIN_VAR_RQCMDARG, "Number of seconds that a semaphore can be held. If semaphore wait crosses" "this value, server will crash", nullptr, nullptr, 600, 25, 600, 0) |
|
static | MYSQL_SYSVAR_ULONG (purge_batch_size, srv_purge_batch_size, PLUGIN_VAR_OPCMDARG, "Number of UNDO log pages to purge in one batch from the history list.", nullptr, nullptr, 300, 1, 5000, 0) |
|
static | MYSQL_SYSVAR_ULONG (purge_threads, srv_n_purge_threads, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Purge threads can be from 1 to 32. Default is 1 if number of available " "CPUs is 16 or less, 4 otherwise.", nullptr, nullptr,(std::thread::hardware_concurrency()<=16 ? 1UL :4UL), 1, MAX_PURGE_THREADS, 0) |
|
static | MYSQL_SYSVAR_ULONG (sync_array_size, srv_sync_array_size, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Size of the mutex/lock wait array.", nullptr, nullptr, 1, 1, 1024, 0) |
|
static | MYSQL_SYSVAR_ULONG (fast_shutdown, srv_fast_shutdown, PLUGIN_VAR_OPCMDARG, "Speeds up the shutdown process of the InnoDB storage engine. Possible" " values are 0, 1 (faster) or 2 (fastest - crash-like).", nullptr, nullptr, 1, 0, 2, 0) |
|
static | MYSQL_SYSVAR_BOOL (file_per_table, srv_file_per_table, PLUGIN_VAR_NOCMDARG, "Stores each InnoDB table to an .ibd file in the database dir.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_STR (ft_server_stopword_table, innobase_server_stopword_table, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_MEMALLOC, "The user supplied stopword table name.", innodb_stopword_table_validate, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_UINT (flush_log_at_timeout, srv_flush_log_at_timeout, PLUGIN_VAR_OPCMDARG, "Write and flush logs every (n) second.", nullptr, nullptr, 1, 0, 2700, 0) |
|
static | MYSQL_SYSVAR_ULONG (flush_log_at_trx_commit, srv_flush_log_at_trx_commit, PLUGIN_VAR_OPCMDARG, "Set to 0 (write and flush once per second)," " 1 (write and flush at each commit)," " or 2 (write at commit, flush once per second).", nullptr, nullptr, 1, 0, 2, 0) |
|
static | MYSQL_SYSVAR_ENUM (flush_method, innodb_flush_method, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "With which method to flush data", nullptr, nullptr, 0, &innodb_flush_method_typelib) |
|
static | MYSQL_SYSVAR_BOOL (force_load_corrupted, srv_load_corrupted, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Force InnoDB to load metadata of corrupted table.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_STR (log_group_home_dir, srv_log_group_home_dir, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Path to InnoDB log files.", nullptr, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_ULONG (page_cleaners, srv_n_page_cleaners, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Page cleaner threads can be from 1 to 64. Default " "is number of buffer pool instances.", nullptr, nullptr, 1, 1, 64, 0) |
|
static | MYSQL_SYSVAR_DOUBLE (max_dirty_pages_pct, srv_max_buf_pool_modified_pct, PLUGIN_VAR_RQCMDARG, "Percentage of dirty pages allowed in bufferpool.", nullptr, innodb_max_dirty_pages_pct_update, 90.0, 0, 99.999, 0) |
|
static | MYSQL_SYSVAR_DOUBLE (max_dirty_pages_pct_lwm, srv_max_dirty_pages_pct_lwm, PLUGIN_VAR_RQCMDARG, "Percentage of dirty pages at which flushing kicks in.", nullptr, innodb_max_dirty_pages_pct_lwm_update, 10, 0, 99.999, 0) |
|
static | MYSQL_SYSVAR_ULONG (adaptive_flushing_lwm, srv_adaptive_flushing_lwm, PLUGIN_VAR_RQCMDARG, "Percentage of log capacity below which no adaptive flushing happens.", nullptr, nullptr, 10, 0, 70, 0) |
|
static | MYSQL_SYSVAR_BOOL (adaptive_flushing, srv_adaptive_flushing, PLUGIN_VAR_NOCMDARG, "Attempt flushing dirty pages to avoid IO bursts at checkpoints.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (flush_sync, srv_flush_sync, PLUGIN_VAR_NOCMDARG, "Allow IO bursts at the checkpoints ignoring io_capacity setting.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ULONG (flushing_avg_loops, srv_flushing_avg_loops, PLUGIN_VAR_RQCMDARG, "Number of iterations over which the background flushing is averaged.", nullptr, nullptr, 30, 1, 1000, 0) |
|
static | MYSQL_SYSVAR_ULONG (max_purge_lag, srv_max_purge_lag, PLUGIN_VAR_RQCMDARG, "Desired maximum length of the purge queue (0 = no limit)", nullptr, nullptr, 0, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (max_purge_lag_delay, srv_max_purge_lag_delay, PLUGIN_VAR_RQCMDARG, "Maximum delay of user threads in micro-seconds", nullptr, nullptr, 0L, 0L, 10000000UL, 0) |
|
static | MYSQL_SYSVAR_BOOL (rollback_on_timeout, innobase_rollback_on_timeout, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Roll back the complete transaction on lock wait " "timeout, for 4.x compatibility (disabled by default)", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (status_file, innobase_create_status_file, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_NOSYSVAR, "Enable SHOW ENGINE INNODB STATUS output in the innodb_status.<pid> file", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (stats_on_metadata, innobase_stats_on_metadata, PLUGIN_VAR_OPCMDARG, "Enable statistics gathering for metadata commands such as" " SHOW TABLE STATUS for tables that use transient statistics (off by " "default)", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONGLONG (stats_transient_sample_pages, srv_stats_transient_sample_pages, PLUGIN_VAR_RQCMDARG, "The number of leaf index pages to sample when calculating transient" " statistics (if persistent statistics are not used, default 8)", nullptr, nullptr, 8, 1, ~0ULL, 0) |
|
static | MYSQL_SYSVAR_BOOL (stats_persistent, srv_stats_persistent, PLUGIN_VAR_OPCMDARG, "InnoDB persistent statistics enabled for all tables unless overridden" " at table level", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (stats_auto_recalc, srv_stats_auto_recalc, PLUGIN_VAR_OPCMDARG, "InnoDB automatic recalculation of persistent statistics enabled for all" " tables unless overridden at table level (automatic recalculation is only" " done when InnoDB decides that the table has changed too much and needs a" " new statistics)", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ULONGLONG (stats_persistent_sample_pages, srv_stats_persistent_sample_pages, PLUGIN_VAR_RQCMDARG, "The number of leaf index pages to sample when calculating persistent" " statistics (by ANALYZE, default 20)", nullptr, nullptr, 20, 1, ~0ULL, 0) |
|
static | MYSQL_SYSVAR_BOOL (adaptive_hash_index, srv_btr_search_enabled, PLUGIN_VAR_OPCMDARG, "Enable InnoDB adaptive hash index (enabled by default). " " Disable with --skip-innodb-adaptive-hash-index.", nullptr, innodb_adaptive_hash_index_update, false) |
|
static | MYSQL_SYSVAR_ULONG (adaptive_hash_index_parts, btr_ahi_parts, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Number of InnoDB Adaptive Hash Index Partitions. (default = 8). ", nullptr, nullptr, 8, 1, 512, 0) |
| Number of distinct partitions of AHI. More...
|
|
static | MYSQL_SYSVAR_ULONG (replication_delay, srv_replication_delay, PLUGIN_VAR_RQCMDARG, "Replication thread delay (ms) on the slave server if" " innodb_thread_concurrency is reached (0 by default)", nullptr, nullptr, 0, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_UINT (compression_level, page_zip_level, PLUGIN_VAR_RQCMDARG, "Compression level used for compressed row format. 0 is no compression" ", 1 is fastest, 9 is best compression and default is 6.", nullptr, nullptr, DEFAULT_COMPRESSION_LEVEL, 0, 9, 0) |
|
static | MYSQL_SYSVAR_BOOL (log_compressed_pages, page_zip_log_pages, PLUGIN_VAR_OPCMDARG, "Enables/disables the logging of entire compressed page images." " InnoDB logs the compressed pages to prevent corruption if" " the zlib compression algorithm changes." " When turned OFF, InnoDB will assume that the zlib" " compression algorithm doesn't change.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ULONG (autoextend_increment, sys_tablespace_auto_extend_increment, PLUGIN_VAR_RQCMDARG, "Data file autoextend increment in megabytes", nullptr, nullptr, 64L, 1L, 1000L, 0) |
|
static | MYSQL_SYSVAR_BOOL (dedicated_server, srv_dedicated_server, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_NOPERSIST|PLUGIN_VAR_READONLY, "Automatically scale innodb_buffer_pool_size and innodb_redo_log_capacity " "based on system memory.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_DOUBLE (segment_reserve_factor, fseg_reserve_pct, PLUGIN_VAR_OPCMDARG, "The segment_reserve_factor is the ratio x/y expressed in percentage," " where x is the number of free pages in the segment, and y is the total" " number of pages in the segment. The number of used pages in the segment" " is given by (y-x). The number of free pages in the segment (x) will be" " maintained such that the actual segment_reserve_factor will be >= the" " requested segment_reserve_factor, which is contained in this variable.", nullptr, nullptr, FSEG_RESERVE_PCT_DFLT, FSEG_RESERVE_PCT_MIN, FSEG_RESERVE_PCT_MAX, 0) |
|
static | MYSQL_SYSVAR_LONGLONG (buffer_pool_size, srv_buf_pool_curr_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_PERSIST_AS_READ_ONLY, "The size of the memory buffer InnoDB uses to " "cache data and indexes of its tables.", nullptr, innodb_buffer_pool_size_update, static_cast< longlong >(srv_buf_pool_def_size), static_cast< longlong >(srv_buf_pool_min_size), longlong{srv_buf_pool_max_size}, 1024 *1024L) |
|
static | MYSQL_SYSVAR_ULONGLONG (buffer_pool_chunk_size, srv_buf_pool_chunk_unit, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Size of a single memory chunk within each buffer pool instance" " for resizing buffer pool. Online buffer pool resizing happens" " at this granularity.", nullptr, nullptr, 128 *1024 *1024, ulonglong{srv_buf_pool_chunk_unit_min}, ulonglong{srv_buf_pool_chunk_unit_max}, ulonglong{srv_buf_pool_chunk_unit_blk_sz}) |
|
static | MYSQL_SYSVAR_ULONG (page_hash_locks, srv_n_page_hash_locks, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Number of rw_locks protecting buffer pool " "page_hash. Rounded up to the next power of 2", nullptr, nullptr, 16, 1, MAX_PAGE_HASH_LOCKS, 0) |
|
static | MYSQL_SYSVAR_BOOL (validate_tablespace_paths, srv_validate_tablespace_paths, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Enable validation of tablespace paths against the DD. (enabled by " "default)." " Disable with --skip-innodb-validate-tablespace-paths.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (use_fdatasync, srv_use_fdatasync, PLUGIN_VAR_NOCMDARG, "Use fdatasync() instead of the default fsync().", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ENUM (doublewrite, dblwr::g_mode, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_NOPERSIST, "Enable InnoDB doublewrite buffer (enabled by default)." " Disable with --skip-innodb-doublewrite.", nullptr, doublewrite_update, dblwr::Mode::ON, &innodb_doublewrite_typelib) |
|
static | MYSQL_SYSVAR_BOOL (extend_and_initialize, tbsp_extend_and_initialize, PLUGIN_VAR_NOCMDARG, "Initialize the allocated space by writing zeros (enabled by default).", nullptr, innodb_extend_and_initialize_update, true) |
|
static | MYSQL_SYSVAR_STR (doublewrite_dir, innobase_doublewrite_dir, PLUGIN_VAR_READONLY, "Use a separate directory for the doublewrite buffer files, ", nullptr, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_ULONG (doublewrite_pages, dblwr::n_pages, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of double write pages per thread", nullptr, nullptr, 128, 1, 512, 0) |
|
static | MYSQL_SYSVAR_ULONG (doublewrite_files, dblwr::n_files, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of double write files", nullptr, nullptr, 2, 1, 256, 0) |
|
static | MYSQL_SYSVAR_ULONG (doublewrite_batch_size, dblwr::batch_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of double write pages to write in a batch", nullptr, nullptr, 0, 0, 256, 0) |
|
static | MYSQL_SYSVAR_ULONG (buffer_pool_instances, srv_buf_pool_instances, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of buffer pool instances, set to higher " "value on high-end machines to increase scalability", nullptr, nullptr, srv_buf_pool_instances_default, 0, MAX_BUFFER_POOLS, 0) |
|
static | MYSQL_SYSVAR_STR (buffer_pool_filename, srv_buf_dump_filename, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_MEMALLOC, "Filename to/from which to dump/load the InnoDB buffer pool", innodb_srv_buf_dump_filename_validate, nullptr, SRV_BUF_DUMP_FILENAME_DEFAULT) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_dump_now, innodb_buffer_pool_dump_now, PLUGIN_VAR_RQCMDARG, "Trigger an immediate dump of the buffer pool into a " "file named @@innodb_buffer_pool_filename", nullptr, buffer_pool_dump_now, false) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_dump_at_shutdown, srv_buffer_pool_dump_at_shutdown, PLUGIN_VAR_RQCMDARG, "Dump the buffer pool into a file named @@innodb_buffer_pool_filename", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_in_core_file, srv_buffer_pool_in_core_file, PLUGIN_VAR_NOCMDARG, "This option has no effect if @@core_file is OFF. " "If @@core_file is ON, and this option is OFF, then the core dump file will" " be generated only if it is possible to exclude buffer pool from it. " "As soon as it will be determined that such exclusion is impossible a " "warning will be emitted and @@core_file will be set to OFF to prevent " "generating a core dump. If this option is enabled then core dumping logic " "will not be affected. This option is disabled by default if the platforms " "supports MADV_DONTDUMP, otherwise it is enabled by default.", nullptr, innodb_srv_buffer_pool_in_core_file_update, BP_IN_CORE_DEFAULT) |
|
static | MYSQL_SYSVAR_ULONG (buffer_pool_dump_pct, srv_buf_pool_dump_pct, PLUGIN_VAR_RQCMDARG, "Dump only the hottest N% of each buffer pool, defaults to 25", nullptr, nullptr, 25, 1, 100, 0) |
|
static | MYSQL_SYSVAR_ULONG (idle_flush_pct, srv_idle_flush_pct, PLUGIN_VAR_RQCMDARG, "Up to what percentage of dirty pages to be flushed when server is found" " idle.", nullptr, nullptr, srv_idle_flush_pct_default, 0, 100, 0) |
|
static | MYSQL_SYSVAR_STR (buffer_pool_evict, srv_buffer_pool_evict, PLUGIN_VAR_RQCMDARG, "Evict pages from the buffer pool", nullptr, innodb_buffer_pool_evict_update, "") |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_load_now, innodb_buffer_pool_load_now, PLUGIN_VAR_RQCMDARG, "Trigger an immediate load of the buffer pool from a " "file named @@innodb_buffer_pool_filename", nullptr, buffer_pool_load_now, false) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_load_abort, innodb_buffer_pool_load_abort, PLUGIN_VAR_RQCMDARG, "Abort a currently running load of the buffer pool", nullptr, buffer_pool_load_abort, false) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_load_at_startup, srv_buffer_pool_load_at_startup, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Load the buffer pool from a file named @@innodb_buffer_pool_filename", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ULONG (lru_scan_depth, srv_LRU_scan_depth, PLUGIN_VAR_RQCMDARG, "How deep to scan LRU to keep it clean", nullptr, nullptr, 1024, 100, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (flush_neighbors, srv_flush_neighbors, PLUGIN_VAR_OPCMDARG, "Set to 0 (don't flush neighbors from buffer pool)," " 1 (flush contiguous neighbors from buffer pool)" " or 2 (flush neighbors from buffer pool)," " when flushing a block", nullptr, nullptr, 0, 0, 2, 0) |
|
static | MYSQL_SYSVAR_ULONG (commit_concurrency, innobase_commit_concurrency, PLUGIN_VAR_RQCMDARG, "Helps in performance tuning in heavily concurrent environments.", innobase_commit_concurrency_validate, nullptr, 0, 0, 1000, 0) |
|
static | MYSQL_SYSVAR_ULONG (concurrency_tickets, srv_n_free_tickets_to_enter, PLUGIN_VAR_RQCMDARG, "Number of times a thread is allowed to enter InnoDB " "within the same SQL query after it has once got the " "ticket", nullptr, nullptr, 5000L, 1L, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_BOOL (deadlock_detect, innobase_deadlock_detect, PLUGIN_VAR_NOCMDARG, "Enable/disable InnoDB deadlock detector (default ON)." " if set to OFF, deadlock detection is skipped," " and we rely on innodb_lock_wait_timeout in case of deadlock.", nullptr, innobase_deadlock_detect_update, true) |
|
static | MYSQL_SYSVAR_LONG (fill_factor, ddl::fill_factor, PLUGIN_VAR_RQCMDARG, "Percentage of B-tree page filled during bulk insert", nullptr, nullptr, 100, 10, 100, 0) |
|
static | MYSQL_SYSVAR_BOOL (ft_enable_diag_print, fts_enable_diag_print, PLUGIN_VAR_OPCMDARG, "Whether to enable additional FTS diagnostic printout ", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (disable_sort_file_cache, srv_disable_sort_file_cache, PLUGIN_VAR_OPCMDARG, "Whether to disable OS system file cache for sort I/O", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_STR (ft_aux_table, fts_internal_tbl_name, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_MEMALLOC, "FTS internal auxiliary table to be checked", innodb_internal_table_validate, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_ULONG (ft_cache_size, fts_max_cache_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "InnoDB Fulltext search cache size in bytes", nullptr, nullptr, 8000000, 1600000, 80000000, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_total_cache_size, fts_max_total_cache_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Total memory allocated for InnoDB Fulltext Search cache", nullptr, nullptr, 640000000, 32000000, 1600000000, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_result_cache_limit, fts_result_cache_limit, PLUGIN_VAR_RQCMDARG, "InnoDB Fulltext search query result cache limit in bytes", nullptr, nullptr, 2000000000L, 1000000L, 4294967295UL, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_min_token_size, fts_min_token_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "InnoDB Fulltext search minimum token size in characters", nullptr, nullptr, 3, 0, 16, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_max_token_size, fts_max_token_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "InnoDB Fulltext search maximum token size in characters", nullptr, nullptr, FTS_MAX_WORD_LEN_IN_CHAR, 10, FTS_MAX_WORD_LEN_IN_CHAR, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_num_word_optimize, fts_num_word_optimize, PLUGIN_VAR_OPCMDARG, "InnoDB Fulltext search number of words to optimize " "for each optimize table call ", nullptr, nullptr, 2000, 1000, 10000, 0) |
|
static | MYSQL_SYSVAR_ULONG (ft_sort_pll_degree, ddl::fts_parser_threads, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "InnoDB Fulltext search parallel sort degree, will " "round up to nearest power of 2 number", nullptr, nullptr, 2, 1, 16, 0) |
|
static | MYSQL_SYSVAR_ULONG (sort_buffer_size, srv_sort_buf_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Memory buffer size for index creation", nullptr, nullptr, 1048576, 65536, 64<< 20, 0) |
|
static | MYSQL_SYSVAR_ULONGLONG (online_alter_log_max_size, srv_online_max_size, PLUGIN_VAR_RQCMDARG, "Maximum modification log file size for online index creation", nullptr, nullptr, 128<< 20, 65536, ~0ULL, 0) |
|
static | MYSQL_SYSVAR_BOOL (optimize_fulltext_only, innodb_optimize_fulltext_only, PLUGIN_VAR_NOCMDARG, "Only optimize the Fulltext index of the table", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (read_io_threads, srv_n_read_io_threads, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of background read I/O threads in InnoDB.", nullptr, nullptr, std::clamp(std::thread::hardware_concurrency()/2, 4U, 64U), 1, 64, 0) |
|
static | MYSQL_SYSVAR_ULONG (write_io_threads, srv_n_write_io_threads, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of background write I/O threads in InnoDB.", nullptr, nullptr, 4, 1, 64, 0) |
|
static | MYSQL_SYSVAR_ULONG (force_recovery, srv_force_recovery, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Helps to save your data in case the disk image of " "the database becomes corrupt.", nullptr, nullptr, 0, 0, 6, 0) |
|
static | MYSQL_SYSVAR_ULONG (force_recovery_crash, srv_force_recovery_crash, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Kills the server during crash recovery.", nullptr, nullptr, 0, 0, 100, 0) |
|
static | MYSQL_SYSVAR_ULONG (page_size, srv_page_size, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Page size to use for all InnoDB tablespaces.", nullptr, nullptr, UNIV_PAGE_SIZE_DEF, UNIV_PAGE_SIZE_MIN, UNIV_PAGE_SIZE_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (log_buffer_size, srv_log_buffer_size, PLUGIN_VAR_RQCMDARG, "The size of the buffer which InnoDB uses to write log to the log files" " on disk.", nullptr, innodb_log_buffer_size_update, INNODB_LOG_BUFFER_SIZE_DEFAULT, INNODB_LOG_BUFFER_SIZE_MIN, INNODB_LOG_BUFFER_SIZE_MAX, 1024) |
|
static | MYSQL_SYSVAR_ULONGLONG (log_file_size, srv_log_file_size, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Size of each log file before upgrading to 8.0.30. Deprecated.", nullptr, nullptr, 48 *1024 *1024L, 4 *1024 *1024L, ULLONG_MAX, 1024 *1024L) |
|
static | MYSQL_SYSVAR_ULONG (log_files_in_group, srv_log_n_files, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "Number of log files before upgrading to 8.0.30. Deprecated.", nullptr, nullptr, 2, 2, 100, 0) |
|
static | MYSQL_SYSVAR_ULONGLONG (redo_log_capacity, srv_redo_log_capacity, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_PERSIST_AS_READ_ONLY, "Limitation for total size of redo log files on disk (expressed in bytes).", nullptr, innodb_redo_log_capacity_update, 100 *1024 *1024, LOG_CAPACITY_MIN, LOG_CAPACITY_MAX, MB) |
|
static | MYSQL_SYSVAR_ULONG (log_write_ahead_size, srv_log_write_ahead_size, PLUGIN_VAR_RQCMDARG, "Log write ahead unit size to avoid read-on-write," " it should match the OS cache block IO size.", nullptr, innodb_log_write_ahead_size_update, INNODB_LOG_WRITE_AHEAD_SIZE_DEFAULT, INNODB_LOG_WRITE_AHEAD_SIZE_MIN, INNODB_LOG_WRITE_AHEAD_SIZE_MAX, OS_FILE_LOG_BLOCK_SIZE) |
|
static | MYSQL_SYSVAR_BOOL (log_writer_threads, srv_log_writer_threads, PLUGIN_VAR_RQCMDARG, "Whether the log writer threads should be activated (ON), or write/flush " "of the redo log should be done by each thread individually (OFF).", nullptr, innodb_log_writer_threads_update, std::thread::hardware_concurrency() >=32) |
|
static | MYSQL_SYSVAR_UINT (log_spin_cpu_abs_lwm, srv_log_spin_cpu_abs_lwm, PLUGIN_VAR_RQCMDARG, "Minimum value of cpu time for which spin-delay is used." " Expressed in percentage of single cpu core.", nullptr, nullptr, INNODB_LOG_SPIN_CPU_ABS_LWM_DEFAULT, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_UINT (log_spin_cpu_pct_hwm, srv_log_spin_cpu_pct_hwm, PLUGIN_VAR_RQCMDARG, "Maximum value of cpu time for which spin-delay is used." " Expressed in percentage of all cpu cores.", nullptr, nullptr, INNODB_LOG_SPIN_CPU_PCT_HWM_DEFAULT, 0, 100, 0) |
|
static | MYSQL_SYSVAR_ULONG (log_wait_for_flush_spin_hwm, srv_log_wait_for_flush_spin_hwm, PLUGIN_VAR_RQCMDARG, "Maximum value of average log flush time for which spin-delay is used." " When flushing takes longer, user threads no longer spin when waiting for" "flushed redo. Expressed in microseconds.", nullptr, nullptr, INNODB_LOG_WAIT_FOR_FLUSH_SPIN_HWM_DEFAULT, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_UINT (old_blocks_pct, innobase_old_blocks_pct, PLUGIN_VAR_RQCMDARG, "Percentage of the buffer pool to reserve for 'old' blocks.", nullptr, innodb_old_blocks_pct_update, 100 *3/8, 5, 95, 0) |
|
static | MYSQL_SYSVAR_UINT (old_blocks_time, buf_LRU_old_threshold, PLUGIN_VAR_RQCMDARG, "Move blocks to the 'new' end of the buffer pool if the first access" " was at least this many milliseconds ago." " The timeout is disabled if 0.", nullptr, nullptr, 1000, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_LONG (open_files, innobase_open_files, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "How many files at the maximum InnoDB keeps open at the same time.", nullptr, nullptr, 0L, 0L, INT32_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (sync_spin_loops, srv_n_spin_wait_rounds, PLUGIN_VAR_RQCMDARG, "Count of spin-loop rounds in InnoDB mutexes (30 by default)", nullptr, nullptr, 30L, 0L, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (spin_wait_delay, srv_spin_wait_delay, PLUGIN_VAR_OPCMDARG, "Maximum delay between polling for a spin lock (6 by default)", nullptr, nullptr, 6L, 0L, 1000, 0) |
|
static | MYSQL_SYSVAR_ULONG (spin_wait_pause_multiplier, ut::spin_wait_pause_multiplier, PLUGIN_VAR_RQCMDARG, "Controls how many times in a row to use a PAUSE " "instruction to achieve one unit of delay in a spin " "lock (see @@innodb_spin_wait_delay), defaults to 50", nullptr, nullptr, 50, 0, 100, 0) |
|
static | MYSQL_SYSVAR_ULONGLONG (fsync_threshold, os_fsync_threshold, PLUGIN_VAR_RQCMDARG, "The value of this variable determines how often InnoDB calls fsync when " "creating a new file. Default is zero which would make InnoDB flush the " "entire file at once before closing it.", nullptr, nullptr, 0, 0, ~0ULL, UNIV_PAGE_SIZE) |
|
static | MYSQL_SYSVAR_ULONG (thread_concurrency, srv_thread_concurrency, PLUGIN_VAR_RQCMDARG, "Helps in performance tuning in heavily concurrent " "environments. Sets the maximum number of threads " "allowed inside InnoDB. Value 0 will disable the " "thread throttling.", nullptr, innodb_thread_concurrency_update, 0, 0, 1000, 0) |
|
static | MYSQL_SYSVAR_ULONG (adaptive_max_sleep_delay, srv_adaptive_max_sleep_delay, PLUGIN_VAR_RQCMDARG, "The upper limit of the sleep delay in usec. Value of 0 disables it.", nullptr, nullptr, 150000, 0, 1000000, 0) |
|
static | MYSQL_SYSVAR_ULONG (thread_sleep_delay, srv_thread_sleep_delay, PLUGIN_VAR_RQCMDARG, "Time of innodb thread sleeping before joining InnoDB queue (usec)." " Value 0 disable a sleep", nullptr, nullptr, 10000L, 0L, 1000000L, 0) |
|
static | MYSQL_SYSVAR_STR (data_file_path, innobase_data_file_path, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Path to individual files and their sizes.", nullptr, nullptr,(char *)"ibdata1:12M:autoextend") |
|
static | MYSQL_SYSVAR_STR (temp_data_file_path, innobase_temp_data_file_path, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Path to files and their sizes making temp-tablespace.", nullptr, nullptr,(char *)"ibtmp1:12M:autoextend") |
|
static | MYSQL_SYSVAR_STR (undo_directory, srv_undo_dir, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Directory where undo tablespace files live, this path can be absolute.", nullptr, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_STR (temp_tablespaces_dir, ibt::srv_temp_dir, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Directory where temp tablespace files live, this path can be absolute.", nullptr, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_ULONG (undo_tablespaces, srv_undo_tablespaces, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_NOPERSIST, "Number of undo tablespaces to use. (deprecated)", nullptr, innodb_undo_tablespaces_update, FSP_IMPLICIT_UNDO_TABLESPACES, FSP_MIN_UNDO_TABLESPACES, FSP_MAX_UNDO_TABLESPACES, 0) |
|
static | MYSQL_SYSVAR_ULONGLONG (max_undo_log_size, srv_max_undo_tablespace_size, PLUGIN_VAR_OPCMDARG, "Maximum size of an UNDO tablespace in MB (If an UNDO tablespace grows" " beyond this size it will be truncated in due course). ", nullptr, nullptr, 1024 *1024 *1024L, 10 *1024 *1024L, ~0ULL, 0) |
|
static | MYSQL_SYSVAR_ULONG (purge_rseg_truncate_frequency, srv_purge_rseg_truncate_frequency, PLUGIN_VAR_OPCMDARG, "Dictates rate at which UNDO records are purged. Value N means" " purge rollback segment(s) on every Nth iteration of purge invocation", nullptr, nullptr, 128, 1, 128, 0) |
|
static | MYSQL_SYSVAR_BOOL (undo_log_truncate, srv_undo_log_truncate, PLUGIN_VAR_OPCMDARG, "Enable or Disable Truncate of UNDO tablespace.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_ULONG (rollback_segments, srv_rollback_segments, PLUGIN_VAR_OPCMDARG, "Number of rollback segments per tablespace. This applies to the system" " tablespace, the temporary tablespace & any undo tablespace.", nullptr, innodb_rollback_segments_update, FSP_MAX_ROLLBACK_SEGMENTS, 1, FSP_MAX_ROLLBACK_SEGMENTS, 0) |
|
static | MYSQL_SYSVAR_BOOL (undo_log_encrypt, srv_undo_log_encrypt, PLUGIN_VAR_OPCMDARG, "Enable or disable Encrypt of UNDO tablespace.", validate_innodb_undo_log_encrypt, nullptr, false) |
|
static | MYSQL_SYSVAR_LONG (autoinc_lock_mode, innobase_autoinc_lock_mode, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY, "The AUTOINC lock modes supported by InnoDB:" " 0 => Old style AUTOINC locking (for backward compatibility);" " 1 => New style AUTOINC locking;" " 2 => No AUTOINC locking (unsafe for SBR)", nullptr, nullptr, AUTOINC_NO_LOCKING, AUTOINC_OLD_STYLE_LOCKING, AUTOINC_NO_LOCKING, 0) |
|
static | MYSQL_SYSVAR_STR (version, innodb_version_str, PLUGIN_VAR_NOCMDOPT|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "InnoDB version", nullptr, nullptr, INNODB_VERSION_STR) |
|
static | MYSQL_SYSVAR_BOOL (use_native_aio, srv_use_native_aio, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Use native AIO if supported on this platform.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (numa_interleave, srv_numa_interleave, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Use NUMA interleave memory policy to allocate InnoDB buffer pool.", nullptr, nullptr, true) |
|
static | MYSQL_SYSVAR_BOOL (api_enable_binlog, ib_binlog_enabled, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Enable binlog for applications direct access InnoDB through InnoDB APIs", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (api_enable_mdl, ib_mdl_enabled, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Enable MDL for applications direct access InnoDB through InnoDB APIs", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (api_disable_rowlock, ib_disable_row_lock, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_READONLY, "Disable row lock when direct access InnoDB through InnoDB APIs", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (api_trx_level, ib_trx_level_setting, PLUGIN_VAR_OPCMDARG, "InnoDB API transaction isolation level", nullptr, nullptr, 0, 0, 3, 0) |
|
static | MYSQL_SYSVAR_ULONG (api_bk_commit_interval, ib_bk_commit_interval, PLUGIN_VAR_OPCMDARG, "Background commit interval in seconds", nullptr, nullptr, 5, 1, 1024 *1024 *1024, 0) |
|
static | MYSQL_SYSVAR_ENUM (change_buffering, innodb_change_buffering, PLUGIN_VAR_RQCMDARG, "Buffer changes to reduce random access:" " OFF (default), ON, inserting, deleting, changing, or purging.", nullptr, nullptr, IBUF_USE_NONE, &innodb_change_buffering_typelib) |
|
static | MYSQL_SYSVAR_UINT (change_buffer_max_size, srv_change_buffer_max_size, PLUGIN_VAR_RQCMDARG, "Maximum on-disk size of change buffer in terms of percentage" " of the buffer pool.", nullptr, innodb_change_buffer_max_size_update, CHANGE_BUFFER_DEFAULT_SIZE, 0, 50, 0) |
|
static | MYSQL_SYSVAR_ENUM (stats_method, srv_innodb_stats_method, PLUGIN_VAR_RQCMDARG, "Specifies how InnoDB index statistics collection code should" " treat NULLs. Possible values are NULLS_EQUAL (default)," " NULLS_UNEQUAL and NULLS_IGNORED", nullptr, nullptr, SRV_STATS_NULLS_EQUAL, &innodb_stats_method_typelib) |
|
static | MYSQL_SYSVAR_UINT (change_buffering_debug, ibuf_debug, PLUGIN_VAR_RQCMDARG, "Debug flags for InnoDB change buffering (0=none, 2=crash at merge)", nullptr, nullptr, 0, 0, 2, 0) |
|
static | MYSQL_SYSVAR_BOOL (disable_background_merge, srv_ibuf_disable_background_merge, PLUGIN_VAR_NOCMDARG|PLUGIN_VAR_RQCMDARG, "Disable change buffering merges by the master thread", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ENUM (compress_debug, srv_debug_compress, PLUGIN_VAR_RQCMDARG, "Compress all tables, without specifying the COMPRESS table attribute", nullptr, nullptr, Compression::NONE, &innodb_debug_compress_typelib) |
|
static | MYSQL_SYSVAR_BOOL (random_read_ahead, srv_random_read_ahead, PLUGIN_VAR_NOCMDARG, "Whether to use read ahead for random access within an extent.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (read_ahead_threshold, srv_read_ahead_threshold, PLUGIN_VAR_RQCMDARG, "Number of pages that must be accessed sequentially for InnoDB to" " trigger a readahead.", nullptr, nullptr, 56, 0, 64, 0) |
|
static | MYSQL_SYSVAR_STR (monitor_enable, innobase_enable_monitor_counter, PLUGIN_VAR_RQCMDARG, "Turn on a monitor counter", innodb_monitor_validate, innodb_enable_monitor_update, nullptr) |
|
static | MYSQL_SYSVAR_STR (monitor_disable, innobase_disable_monitor_counter, PLUGIN_VAR_RQCMDARG, "Turn off a monitor counter", innodb_monitor_validate, innodb_disable_monitor_update, nullptr) |
|
static | MYSQL_SYSVAR_STR (monitor_reset, innobase_reset_monitor_counter, PLUGIN_VAR_RQCMDARG, "Reset a monitor counter", innodb_monitor_validate, innodb_reset_monitor_update, nullptr) |
|
static | MYSQL_SYSVAR_STR (monitor_reset_all, innobase_reset_all_monitor_counter, PLUGIN_VAR_RQCMDARG, "Reset all values for a monitor counter", innodb_monitor_validate, innodb_reset_all_monitor_update, nullptr) |
|
static | MYSQL_SYSVAR_BOOL (status_output, srv_print_innodb_monitor, PLUGIN_VAR_OPCMDARG, "Enable InnoDB monitor output to the error log.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (status_output_locks, srv_print_innodb_lock_monitor, PLUGIN_VAR_OPCMDARG, "Enable InnoDB lock monitor output to the error log." " Requires innodb_status_output=ON.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (print_all_deadlocks, srv_print_all_deadlocks, PLUGIN_VAR_OPCMDARG, "Print all deadlocks to MySQL error log (off by default)", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (compression_failure_threshold_pct, zip_failure_threshold_pct, PLUGIN_VAR_OPCMDARG, "If the compression failure rate of a table is greater than this number" " more padding is added to the pages to reduce the failures. A value of" " zero implies no padding", nullptr, nullptr, 5, 0, 100, 0) |
|
static | MYSQL_SYSVAR_ULONG (compression_pad_pct_max, zip_pad_max, PLUGIN_VAR_OPCMDARG, "Percentage of empty space on a data page that can be reserved" " to make the page compressible.", nullptr, nullptr, 50, 0, 75, 0) |
|
static | MYSQL_SYSVAR_BOOL (read_only, srv_read_only_mode, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "Start InnoDB in read only mode (off by default)", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (cmp_per_index_enabled, srv_cmp_per_index_enabled, PLUGIN_VAR_OPCMDARG, "Enable INFORMATION_SCHEMA.innodb_cmp_per_index," " may have negative impact on performance (off by default)", nullptr, innodb_cmp_per_index_update, false) |
|
static | MYSQL_SYSVAR_ENUM (default_row_format, innodb_default_row_format, PLUGIN_VAR_RQCMDARG, "The default ROW FORMAT for all innodb tables created without explicit" " ROW_FORMAT. Possible values are REDUNDANT, COMPACT, and DYNAMIC." " The ROW_FORMAT value COMPRESSED is not allowed", nullptr, nullptr, DEFAULT_ROW_FORMAT_DYNAMIC, &innodb_default_row_format_typelib) |
|
static | MYSQL_SYSVAR_STR (redo_log_archive_dirs, meb::redo_log_archive_dirs, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_MEMALLOC, "Limit the location of the redo log archive to the semicolon " "separated list of labeled directories", meb::validate_redo_log_archive_dirs, nullptr, nullptr) |
|
static | MYSQL_SYSVAR_BOOL (redo_log_encrypt, srv_redo_log_encrypt, PLUGIN_VAR_OPCMDARG, "Enable or disable Encryption of REDO tablespace.", validate_innodb_redo_log_encrypt, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (print_ddl_logs, srv_print_ddl_logs, PLUGIN_VAR_OPCMDARG, "Print all DDl logs to MySQL error log (off by default)", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_UINT (trx_rseg_n_slots_debug, trx_rseg_n_slots_debug, PLUGIN_VAR_RQCMDARG, "Debug flags for InnoDB to limit TRX_RSEG_N_SLOTS for " "trx_rsegf_undo_find_free()", nullptr, nullptr, 0, 0, 1024, 0) |
|
static | MYSQL_SYSVAR_UINT (limit_optimistic_insert_debug, btr_cur_limit_optimistic_insert_debug, PLUGIN_VAR_RQCMDARG, "Artificially limit the number of records per B-tree page (0=unlimited).", nullptr, nullptr, 0, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_BOOL (trx_purge_view_update_only_debug, srv_purge_view_update_only_debug, PLUGIN_VAR_NOCMDARG, "Pause actual purging any delete-marked records, but " "merely update the purge view." " It is to create artificially the situation the " "purge view have been updated" " but the each purges were not done yet.", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_ULONG (fil_make_page_dirty_debug, srv_fil_make_page_dirty_debug, PLUGIN_VAR_OPCMDARG, "Make the first page of the given tablespace dirty.", nullptr, innodb_make_page_dirty, UINT32_MAX, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_ULONG (saved_page_number_debug, srv_saved_page_number_debug, PLUGIN_VAR_OPCMDARG, "An InnoDB page number.", nullptr, innodb_save_page_no, 0, 0, UINT32_MAX, 0) |
|
static | MYSQL_SYSVAR_BOOL (page_cleaner_disabled_debug, innodb_page_cleaner_disabled_debug, PLUGIN_VAR_OPCMDARG, "Disable page cleaner", nullptr, buf_flush_page_cleaner_disabled_debug_update, false) |
|
static | MYSQL_SYSVAR_BOOL (dict_stats_disabled_debug, innodb_dict_stats_disabled_debug, PLUGIN_VAR_OPCMDARG, "Disable dict_stats thread", nullptr, dict_stats_disabled_debug_update, false) |
|
static | MYSQL_SYSVAR_BOOL (master_thread_disabled_debug, srv_master_thread_disabled_debug, PLUGIN_VAR_OPCMDARG, "Disable master thread", nullptr, srv_master_thread_disabled_debug_update, false) |
|
static | MYSQL_SYSVAR_BOOL (sync_debug, srv_sync_debug, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Enable the sync debug checks", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (buffer_pool_debug, srv_buf_pool_debug, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_READONLY, "Enable buffer pool debug", nullptr, nullptr, false) |
|
static | MYSQL_SYSVAR_BOOL (ddl_log_crash_reset_debug, innodb_ddl_log_crash_reset_debug, PLUGIN_VAR_OPCMDARG, "Reset all crash injection counters to 1", nullptr, ddl_log_crash_reset, false) |
|
static | MYSQL_SYSVAR_STR (directories, srv_innodb_directories, PLUGIN_VAR_RQCMDARG|PLUGIN_VAR_READONLY|PLUGIN_VAR_NOPERSIST, "List of directories 'dir1;dir2;..;dirN' to scan for " "tablespace files. Default is to scan " "'innodb-data-home-dir;innodb-undo-directory;datadir'", nullptr, nullptr, nullptr) |
|
static | MYSQL_THDVAR_STR (interpreter, PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_NOPERSIST, "Invoke InnoDB test interpreter with commands" " to be executed.", ib_interpreter_check, ib_interpreter_update, "init") |
| Use this variable innodb_interpreter to execute debug code within InnoDB. More...
|
|
static | MYSQL_THDVAR_STR (interpreter_output, PLUGIN_VAR_READONLY|PLUGIN_VAR_OPCMDARG|PLUGIN_VAR_MEMALLOC|PLUGIN_VAR_NOPERSIST, "Output from InnoDB testing module (ut0test).", nullptr, nullptr, "The Default Value") |
| When testing commands are executed in the innodb_interpreter variable, the output is stored in this innodb_interpreter_output variable. More...
|
|
char ** | thd_innodb_interpreter_output (THD *thd) |
| Obtain the value of the latest output from InnoDB Interpreter/Tester module (ib::Tester). More...
|
|
char ** | thd_innodb_interpreter (THD *thd) |
| Obtain the latest command executed by InnoDB Interpreter/Tester module (ib::Tester). More...
|
|
| mysql_declare_plugin (innobase) |
|
ICP_RESULT | innobase_index_cond (ha_innobase *h) |
| Index Condition Pushdown interface implementation. More...
|
|
void | innobase_init_vc_templ (dict_table_t *table) |
| Get the computed value by supplying the base column values. More...
|
|
void | innobase_rename_vc_templ (dict_table_t *table) |
| Change dbname and table name in table->vc_templ. More...
|
|
dfield_t * | innobase_get_field_from_update_vector (dict_foreign_t *foreign, upd_t *update, uint32_t col_no) |
| Get the updated parent field value from the update vector for the given col_no. More...
|
|
dfield_t * | innobase_get_computed_value (const dtuple_t *row, const dict_v_col_t *col, const dict_index_t *index, mem_heap_t **local_heap, mem_heap_t *heap, const dict_field_t *ifield, THD *thd, TABLE *mysql_table, const dict_table_t *old_table, upd_t *parent_update, dict_foreign_t *foreign) |
| Get the computed value by supplying the base column values. More...
|
|
void | ib_senderrf (THD *thd, ib_log_level_t level, uint32_t code,...) |
| Use this when the args are passed to the format string from messages_to_clients.txt directly as is. More...
|
|
void | ib_errf (THD *thd, ib_log_level_t level, uint32_t code, const char *format,...) |
| Use this when the args are first converted to a formatted string and then passed to the format string from messages_to_clients.txt. More...
|
|
uint | innobase_convert_to_filename_charset (char *to, const char *from, ulint len) |
|
uint | innobase_convert_to_system_charset (char *to, const char *from, ulint len, uint *errors) |
|
void | ib_warn_row_too_big (const dict_table_t *table) |
|
static void | innodb_fill_fake_column_struct (dict_col_t *col, const Ha_fk_column_type *fk_col_type) |
| Constructs fake dict_col_t describing column for foreign key type compatibility check from column description in Ha_fk_column_type form. More...
|
|