sql/rpl_rli.cc (1,691 lines of code) (raw):

/* Copyright (c) 2006, 2018, Oracle and/or its affiliates. All rights reserved. This program is free software; you can redistribute it and/or modify it under the terms of the GNU General Public License as published by the Free Software Foundation; version 2 of the License. This program is distributed in the hope that it will be useful, but WITHOUT ANY WARRANTY; without even the implied warranty of MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the GNU General Public License for more details. You should have received a copy of the GNU General Public License along with this program; if not, write to the Free Software Foundation, 51 Franklin Street, Suite 500, Boston, MA 02110-1335 USA */ #include "sql_priv.h" #include "unireg.h" // HAVE_* #include "rpl_mi.h" #include "rpl_rli.h" #include "sql_base.h" // close_thread_tables #include <my_dir.h> // For MY_STAT #include "log_event.h" // Format_description_log_event, Log_event, // FORMAT_DESCRIPTION_LOG_EVENT, ROTATE_EVENT, // PREFIX_SQL_LOAD #include "rpl_slave.h" #include "rpl_utility.h" #include "transaction.h" #include "sql_parse.h" // end_trans, ROLLBACK #include "rpl_slave.h" #include "rpl_rli_pdb.h" #include "rpl_info_factory.h" #include <mysql/plugin.h> #include <mysql/service_thd_wait.h> #include <chrono> using std::min; using std::max; /* Please every time you add a new field to the relay log info, update what follows. For now, this is just used to get the number of fields. */ const char* info_rli_fields[]= { "number_of_lines", "group_relay_log_name", "group_relay_log_pos", "group_master_log_name", "group_master_log_pos", "sql_delay", "number_of_workers", "id" }; extern "C" uchar *get_gtid_info_key(const uchar *record, size_t *length, my_bool not_used MY_ATTRIBUTE((unused))) { Gtid_info *entry = (Gtid_info *) record; *length = strlen(entry->get_database_name()); return ((uchar*) entry->get_database_name()); } extern "C" void free_gtid_info_entry(Gtid_info *entry) { if (entry) { delete entry; } } Relay_log_info::Relay_log_info(bool is_slave_recovery #ifdef HAVE_PSI_INTERFACE ,PSI_mutex_key *param_key_info_run_lock, PSI_mutex_key *param_key_info_data_lock, PSI_mutex_key *param_key_info_sleep_lock, PSI_mutex_key *param_key_info_thd_lock, PSI_mutex_key *param_key_info_data_cond, PSI_mutex_key *param_key_info_start_cond, PSI_mutex_key *param_key_info_stop_cond, PSI_mutex_key *param_key_info_sleep_cond #endif , uint param_id ) :Rpl_info("SQL" #ifdef HAVE_PSI_INTERFACE ,param_key_info_run_lock, param_key_info_data_lock, param_key_info_sleep_lock, param_key_info_thd_lock, param_key_info_data_cond, param_key_info_start_cond, param_key_info_stop_cond, param_key_info_sleep_cond #endif , param_id ), replicate_same_server_id(::replicate_same_server_id), cur_log_fd(-1), relay_log(&sync_relaylog_period), is_relay_log_recovery(is_slave_recovery), part_event(false), ends_group(false), save_temporary_tables(0), cur_log_old_open_count(0), error_on_rli_init_info(false), group_relay_log_pos(0), event_relay_log_pos(0), group_master_log_pos(0), gtid_set(global_sid_map, global_sid_lock), log_space_total(0), ignore_log_space_limit(0), sql_force_rotate_relay(false), slave_has_caughtup(Enum_slave_caughtup::NONE), last_master_timestamp(0), penultimate_master_timestamp(0), events_since_last_sample(0), slave_skip_counter(0), abort_pos_wait(0), until_condition(UNTIL_NONE), until_log_pos(0), until_sql_gtids(global_sid_map), until_sql_gtids_first_event(true), retried_trans(0), tables_to_lock(0), tables_to_lock_count(0), rows_query_ev(NULL), last_event_start_time(0), deferred_events(NULL), curr_group_seen_gtid(false), curr_group_seen_begin(false), slave_parallel_workers(0), exit_counter(0), max_updated_index(0), recovery_parallel_workers(0), checkpoint_seqno(0), checkpoint_group(opt_mts_checkpoint_group), recovery_groups_inited(false), mts_recovery_group_cnt(0), mts_recovery_index(0), mts_recovery_group_seen_begin(0), mts_group_status(MTS_NOT_IN_GROUP), reported_unsafe_warning(false), rli_description_event(NULL), commit_order_mngr(NULL), sql_delay(0), sql_delay_end(0), m_flags(0), row_stmt_start_timestamp(0), long_find_row_note_printed(false), skip_unique_check(false) { DBUG_ENTER("Relay_log_info::Relay_log_info"); #ifdef HAVE_PSI_INTERFACE relay_log.set_psi_keys(key_RELAYLOG_LOCK_index, key_RELAYLOG_LOCK_commit, key_RELAYLOG_LOCK_commit_queue, key_RELAYLOG_LOCK_semisync, key_RELAYLOG_LOCK_semisync_queue, key_RELAYLOG_LOCK_done, key_RELAYLOG_LOCK_flush_queue, key_RELAYLOG_LOCK_log, key_RELAYLOG_LOCK_sync, key_RELAYLOG_LOCK_sync_queue, key_RELAYLOG_LOCK_xids, key_RELAYLOG_LOCK_non_xid_trxs, key_RELAYLOG_LOCK_binlog_end_pos, key_RELAYLOG_COND_done, key_RELAYLOG_update_cond, key_RELAYLOG_prep_xids_cond, key_RELAYLOG_non_xid_trxs_cond, key_file_relaylog, key_file_relaylog_index); #endif group_relay_log_name[0]= event_relay_log_name[0]= group_master_log_name[0] = last_gtid[0] = 0; until_log_name[0]= ign_master_log_name_end[0]= 0; set_timespec_nsec(last_clock, 0); memset(&cache_buf, 0, sizeof(cache_buf)); cached_charset_invalidate(); memset(peak_lag_last, 0, sizeof(peak_lag_last)); mysql_mutex_init(key_relay_log_info_log_space_lock, &log_space_lock, MY_MUTEX_INIT_FAST); mysql_cond_init(key_relay_log_info_log_space_cond, &log_space_cond, NULL); mysql_mutex_init(key_mutex_slave_parallel_pend_jobs, &pending_jobs_lock, MY_MUTEX_INIT_FAST); mysql_cond_init(key_cond_slave_parallel_pend_jobs, &pending_jobs_cond, NULL); mysql_mutex_init(key_mutex_slave_parallel_worker_count, &exit_count_lock, MY_MUTEX_INIT_FAST); my_atomic_rwlock_init(&slave_open_temp_tables_lock); relay_log.init_pthread_objects(); do_server_version_split(::server_version, slave_version_split); last_retrieved_gtid.clear(); force_flush_postponed_due_to_split_trans= false; init_gtid_infos(); recovery_max_engine_gtid.clear(); recovery_sid_lock= new Checkable_rwlock; recovery_sid_map= new Sid_map(recovery_sid_lock); mysql_mutex_init(0, &dep_lock, MY_MUTEX_INIT_FAST); mysql_mutex_init(0, &dep_key_lookup_mutex, MY_MUTEX_INIT_FAST); mysql_cond_init(0, &dep_full_cond, NULL); mysql_cond_init(0, &dep_empty_cond, NULL); mysql_cond_init(0, &dep_trx_all_done_cond, NULL); DBUG_VOID_RETURN; } /** The method to invoke at slave threads start */ void Relay_log_info::init_workers(ulong n_workers) { /* Parallel slave parameters initialization is done regardless whether the feature is or going to be active or not. */ mts_groups_assigned= mts_events_assigned= pending_jobs= wq_size_waits_cnt= 0; mts_wq_excess_cnt= mts_wq_no_underrun_cnt= mts_wq_overfill_cnt= 0; mts_last_online_stat= 0; my_init_dynamic_array(&workers, sizeof(Slave_worker *), n_workers, 4); } /** The method to invoke at slave threads stop */ void Relay_log_info::deinit_workers() { delete_dynamic(&workers); } void Relay_log_info::init_gtid_infos() { my_init_dynamic_array(&gtid_infos, sizeof(Gtid_info *), 1, 1); gtid_info_hash_inited = (my_hash_init(&map_db_to_gtid_info, &my_charset_bin, 0, 0, 0, (my_hash_get_key) get_gtid_info_key, (my_hash_free_key) free_gtid_info_entry, 0) == 0); mysql_rwlock_init(0, &gtid_info_hash_lock); } void Relay_log_info::deinit_gtid_infos() { delete_dynamic(&gtid_infos); if (gtid_info_hash_inited) my_hash_free(&map_db_to_gtid_info); mysql_rwlock_destroy(&gtid_info_hash_lock); gtid_info_hash_inited = false; } Relay_log_info::~Relay_log_info() { DBUG_ENTER("Relay_log_info::~Relay_log_info"); if (recovery_groups_inited) bitmap_free(&recovery_groups); mysql_mutex_destroy(&log_space_lock); mysql_cond_destroy(&log_space_cond); mysql_mutex_destroy(&pending_jobs_lock); mysql_cond_destroy(&pending_jobs_cond); mysql_mutex_destroy(&exit_count_lock); my_atomic_rwlock_destroy(&slave_open_temp_tables_lock); relay_log.cleanup(); set_rli_description_event(NULL); last_retrieved_gtid.clear(); deinit_gtid_infos(); delete recovery_sid_lock; recovery_sid_lock= NULL; delete recovery_sid_map; recovery_sid_map= NULL; mysql_mutex_destroy(&dep_lock); mysql_mutex_destroy(&dep_key_lookup_mutex); mysql_cond_destroy(&dep_full_cond); mysql_cond_destroy(&dep_empty_cond); DBUG_VOID_RETURN; } /** Method is called when MTS coordinator senses the relay-log name has been changed. It marks each Worker member with this fact to make an action at time it will distribute a terminal event of a group to the Worker. Worker receives the new name at the group commiting phase @c Slave_worker::slave_worker_ends_group(). */ void Relay_log_info::reset_notified_relay_log_change() { if (!is_parallel_exec()) return; for (uint i= 0; i < workers.elements; i++) { Slave_worker *w= *(Slave_worker **) dynamic_array_ptr(&workers, i); w->relay_log_change_notified= FALSE; } } /** This method is called in mts_checkpoint_routine() to mark that each worker is required to adapt to a new checkpoint data whose coordinates are passed to it through GAQ index. Worker notices the new checkpoint value at the group commit to reset the current bitmap and starts using the clean bitmap indexed from zero of being reset checkpoint_seqno. New seconds_behind_master timestamp is installed. @param shift number of bits to shift by Worker due to the current checkpoint change. @param new_ts new seconds_behind_master timestamp value unless zero. Zero could be due to FD event. @param new_ts_millis new milli_seconds_behind_master timestamp value @param need_data_lock False if caller has locked @c data_lock */ void Relay_log_info::reset_notified_checkpoint(ulong shift, time_t new_ts, ulonglong new_ts_millis, bool need_data_lock) { /* If this is not a parallel execution we return immediately. */ if (!is_parallel_exec()) return; for (uint i= 0; i < workers.elements; i++) { Slave_worker *w= *(Slave_worker **) dynamic_array_ptr(&workers, i); /* Reseting the notification information in order to force workers to assign jobs with the new updated information. Notice that the bitmap_shifted is accumulated to indicate how many consecutive jobs were successfully processed. The worker when assigning a new job will set the value back to zero. */ w->checkpoint_notified= FALSE; w->bitmap_shifted= w->bitmap_shifted + shift; /* Zero shift indicates the caller rotates the master binlog. The new name will be passed to W through the group descriptor during the first post-rotation time scheduling. */ if (shift == 0) w->master_log_change_notified= false; DBUG_PRINT("mts", ("reset_notified_checkpoint shift --> %lu, " "worker->bitmap_shifted --> %lu, worker --> %u.", shift, w->bitmap_shifted, i)); } /* There should not be a call where (shift == 0 && checkpoint_seqno != 0). Then the new checkpoint sequence is updated by subtracting the number of consecutive jobs that were successfully processed. */ DBUG_ASSERT(!(shift == 0 && checkpoint_seqno != 0)); checkpoint_seqno= checkpoint_seqno - shift; DBUG_PRINT("mts", ("reset_notified_checkpoint shift --> %lu, " "checkpoint_seqno --> %u.", shift, checkpoint_seqno)); if (new_ts) { if (need_data_lock) mysql_mutex_lock(&data_lock); else mysql_mutex_assert_owner(&data_lock); // Set the flag to say that "the slave has not yet caught up" slave_has_caughtup= Enum_slave_caughtup::NO; set_last_master_timestamp(new_ts, new_ts_millis); if (need_data_lock) mysql_mutex_unlock(&data_lock); } } /** Reset recovery info from Worker info table and mark MTS recovery is completed. @return false on success true when @c reset_notified_checkpoint failed. */ bool Relay_log_info::mts_finalize_recovery() { bool ret= false; uint i; uint repo_type= get_rpl_info_handler()->get_rpl_info_type(); DBUG_ENTER("Relay_log_info::mts_finalize_recovery"); for (i= 0; !ret && i < workers.elements; i++) { Slave_worker *w= *(Slave_worker **) dynamic_array_ptr(&workers, i); ret= w->reset_recovery_info(); DBUG_EXECUTE_IF("mts_debug_recovery_reset_fails", ret= true;); } /* The loop is traversed in the worker index descending order due to specifics of the Worker table repository that does not like even temporary holes. Therefore stale records are deleted from the tail. */ DBUG_EXECUTE_IF("enable_mts_wokrer_failure_in_recovery_finalize", {DBUG_SET("+d,mts_worker_thread_init_fails");}); for (i= recovery_parallel_workers; i > workers.elements && !ret; i--) { Slave_worker *w= Rpl_info_factory::create_worker(repo_type, i - 1, this, true); /* If an error occurs during the above create_worker call, the newly created worker object gets deleted within the above function call itself and only NULL is returned. Hence the following check has been added to verify that a valid worker object exists. */ if (w) { ret= w->remove_info(); delete w; } else { ret= true; goto err; } } recovery_parallel_workers= slave_parallel_workers; err: DBUG_RETURN(ret); } bool Relay_log_info::mts_workers_queue_empty() { Slave_worker *worker= NULL; ulong ret= 0; for (ulong i= 0; i< workers.elements; ++i) { worker= *dynamic_element(&workers, i, Slave_worker**); mysql_mutex_lock(&worker->jobs_lock); ret+= worker->curr_jobs; mysql_mutex_unlock(&worker->jobs_lock); } return ret == 0; } /* Checks if all in-flight stmts/trx can be safely rollbacked */ bool Relay_log_info::cannot_safely_rollback() { if (!is_parallel_exec()) return info_thd->transaction.all.cannot_safely_rollback(); bool ret= false; Slave_worker *worker= NULL; for (ulong i= 0; i< workers.elements; ++i) { worker= *dynamic_element(&workers, i, Slave_worker**); mysql_mutex_lock(&worker->jobs_lock); // workers could have been killed and in that case // the state is NOT_RUNNING. The info_thd would be // destroyed soon/already and hence it would be an // illegal memory read to look at info_thd if (worker->running_status != Slave_worker::NOT_RUNNING) { ret= ret || worker->info_thd->transaction.all.cannot_safely_rollback(); } mysql_mutex_unlock(&worker->jobs_lock); } return ret; } static inline int add_relay_log(Relay_log_info* rli,LOG_INFO* linfo) { MY_STAT s; DBUG_ENTER("add_relay_log"); mysql_mutex_assert_owner(&rli->log_space_lock); if (!mysql_file_stat(key_file_relaylog, linfo->log_file_name, &s, MYF(0))) { sql_print_error("log %s listed in the index, but failed to stat.", linfo->log_file_name); DBUG_RETURN(1); } rli->log_space_total.fetch_add(s.st_size); #ifndef DBUG_OFF char buf[22]; DBUG_PRINT("info",("log_space_total: %s", llstr(rli->log_space_total,buf))); #endif DBUG_RETURN(0); } int Relay_log_info::count_relay_log_space() { LOG_INFO flinfo; DBUG_ENTER("Relay_log_info::count_relay_log_space"); mysql_mutex_lock(&log_space_lock); log_space_total= 0; if (relay_log.find_log_pos(&flinfo, NullS, 1)) { sql_print_error("Could not find first log while counting relay log space."); mysql_mutex_unlock(&log_space_lock); DBUG_RETURN(1); } do { if (add_relay_log(this, &flinfo)) { mysql_mutex_unlock(&log_space_lock); DBUG_RETURN(1); } } while (!relay_log.find_next_log(&flinfo, 1)); /* As we have counted everything, including what may have written in a preceding write, we must reset bytes_written, or we may count some space twice. */ relay_log.reset_bytes_written(); mysql_mutex_unlock(&log_space_lock); DBUG_RETURN(0); } /** Resets UNTIL condition for Relay_log_info */ void Relay_log_info::clear_until_condition() { DBUG_ENTER("clear_until_condition"); until_condition= Relay_log_info::UNTIL_NONE; until_log_name[0]= 0; until_log_pos= 0; until_sql_gtids.clear(); until_sql_gtids_first_event= true; DBUG_VOID_RETURN; } /** * Update the last master timestamp seen by the slave * Last master timestamp is used to calculate lag (seconds/milli-seconds behind * master). */ void Relay_log_info::set_last_master_timestamp(time_t ts, ulonglong ts_millis) { auto now= std::chrono::system_clock::now().time_since_epoch(); auto now_sec= std::chrono::duration_cast<std::chrono::seconds>(now).count(); auto now_msec= std::chrono::duration_cast<std::chrono::milliseconds>(now) .count(); /* Note that we only skip assigning ts to last_master_timestamp when ts is smaller than last_master_timestamp to avoid a sudden spike on second behind master. If ts is very big, say bigger than now(), we will assign the current time to last_master_timestamp instead. Same for last_master_timestamp_millis */ if (ts > last_master_timestamp) { penultimate_master_timestamp= last_master_timestamp; last_master_timestamp= std::min(ts, now_sec); mysql_bin_log.last_master_timestamp.store(last_master_timestamp); } if (ts_millis > last_master_timestamp_millis) last_master_timestamp_millis= std::min(ts_millis, (ulonglong) now_msec); } /** Update the peak lag with the latest event. It accepts one parameter, which is the time this event happened on master. This function will only sample one event every 'peak_lag_sample_rate' events. peak_lag_time is not actually used here. This function always records the most recent event time for each discrete lag value, in seconds. peak_lag_time is only used when calculating the peak, on request. This function uses the local timestamp to compute the interval between two local replay events. @when_master the time stamp when did this event happen on master */ void Relay_log_info::update_peak_lag(time_t when_master) { DBUG_ENTER("update_peak_lag"); if (events_since_last_sample < opt_peak_lag_sample_rate) { ++events_since_last_sample; DBUG_VOID_RETURN; } //sample this event time_t when_slave = time(0); if (((time_t) -1) == when_slave) return; // time() error time_t when_base = when_master + mi->clock_diff_with_master; long lag = 0; if (when_slave > when_base) { lag = long(when_slave) - long(when_base); if (lag > PEAK_LAG_MAX_SECS) { lag = PEAK_LAG_MAX_SECS; } peak_lag_last[lag - 1] = when_slave; } events_since_last_sample = 0; DBUG_VOID_RETURN; } /** Return the peak lag over the last peak_lag_time seconds. peak_lag_last stores the most recent time for each non-zero lag value. @param now the current timestamp. */ time_t Relay_log_info::peak_lag(time_t now) { long ret = 0; time_t start = now - opt_peak_lag_time; for (long cur = PEAK_LAG_MAX_SECS - 1; ret == 0 && cur >= 0; --cur) { if(peak_lag_last[cur] >= start) { ret = cur + 1; } } return time_t(ret); } /** Opens and intialize the given relay log. Specifically, it does what follows: - Closes old open relay log files. - If we are using the same relay log as the running IO-thread, then sets. rli->cur_log to point to the same IO_CACHE entry. - If not, opens the 'log' binary file. @todo check proper initialization of group_master_log_name/group_master_log_pos. /alfranio @param rli[in] Relay information (will be initialized) @param log[in] Name of relay log file to read from. NULL = First log @param pos[in] Position in relay log file @param need_data_lock[in] If true, this function will acquire the relay_log.data_lock(); otherwise the caller should already have acquired it. @param errmsg[out] On error, this function will store a pointer to an error message here @param keep_looking_for_fd[in] If true, this function will look for a Format_description_log_event. We only need this when the SQL thread starts and opens an existing relay log and has to execute it (possibly from an offset >4); then we need to read the first event of the relay log to be able to parse the events we have to execute. @retval 0 ok, @retval 1 error. In this case, *errmsg is set to point to the error message. */ int Relay_log_info::init_relay_log_pos(const char* log, ulonglong pos, bool need_data_lock, const char** errmsg, bool keep_looking_for_fd) { DBUG_ENTER("Relay_log_info::init_relay_log_pos"); DBUG_PRINT("info", ("pos: %lu", (ulong) pos)); *errmsg=0; const char* errmsg_fmt= 0; static char errmsg_buff[MYSQL_ERRMSG_SIZE + FN_REFLEN]; mysql_mutex_t *log_lock= relay_log.get_log_lock(); if (need_data_lock) mysql_mutex_lock(&data_lock); else mysql_mutex_assert_owner(&data_lock); /* By default the relay log is in binlog format 3 (4.0). Even if format is 4, this will work enough to read the first event (Format_desc) (remember that format 4 is just lenghtened compared to format 3; format 3 is a prefix of format 4). */ set_rli_description_event(new Format_description_log_event(3)); mysql_mutex_lock(log_lock); /* Close log file and free buffers if it's already open */ if (cur_log_fd >= 0) { end_io_cache(&cache_buf); mysql_file_close(cur_log_fd, MYF(MY_WME)); cur_log_fd = -1; } group_relay_log_pos= event_relay_log_pos= pos; /* Test to see if the previous run was with the skip of purging If yes, we do not purge when we restart */ if (relay_log.find_log_pos(&linfo, NullS, 1)) { *errmsg="Could not find first log during relay log initialization"; goto err; } if (log && relay_log.find_log_pos(&linfo, log, 1)) { errmsg_fmt= "Could not find target log file mentioned in " "relay log info in the index file '%s' during " "relay log initialization"; sprintf(errmsg_buff, errmsg_fmt, relay_log.get_index_fname()); *errmsg= errmsg_buff; goto err; } strmake(group_relay_log_name, linfo.log_file_name, sizeof(group_relay_log_name) - 1); strmake(event_relay_log_name, linfo.log_file_name, sizeof(event_relay_log_name) - 1); if (relay_log.is_active(linfo.log_file_name)) { /* The IO thread is using this log file. In this case, we will use the same IO_CACHE pointer to read data as the IO thread is using to write data. */ my_b_seek((cur_log=relay_log.get_log_file()), (off_t)0); if (check_binlog_magic(cur_log, errmsg)) goto err; cur_log_old_open_count=relay_log.get_open_count(); } else { /* Open the relay log and set cur_log to point at this one */ if ((cur_log_fd=open_binlog_file(&cache_buf, linfo.log_file_name,errmsg)) < 0) goto err; cur_log = &cache_buf; } /* In all cases, check_binlog_magic() has been called so we're at offset 4 for sure. */ if (pos > BIN_LOG_HEADER_SIZE) /* If pos<=4, we stay at 4 */ { Log_event* ev; while (keep_looking_for_fd) { /* Read the possible Format_description_log_event; if position was 4, no need, it will be read naturally. */ DBUG_PRINT("info",("looking for a Format_description_log_event")); if (my_b_tell(cur_log) >= pos) break; /* Because of we have data_lock and log_lock, we can safely read an event */ if (!(ev= Log_event::read_log_event(cur_log, 0, rli_description_event, opt_slave_sql_verify_checksum, NULL))) { DBUG_PRINT("info",("could not read event, cur_log->error=%d", cur_log->error)); if (cur_log->error) /* not EOF */ { *errmsg= "I/O error reading event at position 4"; goto err; } break; } else if (ev->get_type_code() == FORMAT_DESCRIPTION_EVENT) { DBUG_PRINT("info",("found Format_description_log_event")); set_rli_description_event((Format_description_log_event *)ev); /* As ev was returned by read_log_event, it has passed is_valid(), so my_malloc() in ctor worked, no need to check again. */ /* Ok, we found a Format_description event. But it is not sure that this describes the whole relay log; indeed, one can have this sequence (starting from position 4): Format_desc (of slave) Previous-GTIDs (of slave IO thread, if GTIDs are enabled) Rotate (of master) Format_desc (of master) So the Format_desc which really describes the rest of the relay log can be the 3rd or the 4th event (depending on GTIDs being enabled or not, it can't be further than that, because we rotate the relay log when we queue a Rotate event from the master). But what describes the Rotate is the first Format_desc. So what we do is: go on searching for Format_description events, until you exceed the position (argument 'pos') or until you find an event other than Previous-GTIDs, Rotate or Format_desc. */ } else { DBUG_PRINT("info",("found event of another type=%d", ev->get_type_code())); keep_looking_for_fd= (ev->get_type_code() == ROTATE_EVENT || ev->get_type_code() == PREVIOUS_GTIDS_LOG_EVENT); delete ev; } } my_b_seek(cur_log,(off_t)pos); #ifndef DBUG_OFF { char llbuf1[22], llbuf2[22]; DBUG_PRINT("info", ("my_b_tell(cur_log)=%s >event_relay_log_pos=%s", llstr(my_b_tell(cur_log),llbuf1), llstr(get_event_relay_log_pos(),llbuf2))); } #endif } err: /* If we don't purge, we can't honour relay_log_space_limit ; silently discard it */ if (!relay_log_purge) { log_space_limit= 0; // todo: consider to throw a warning at least } mysql_cond_broadcast(&data_cond); mysql_mutex_unlock(log_lock); if (need_data_lock) mysql_mutex_unlock(&data_lock); if (!rli_description_event->is_valid() && !*errmsg) *errmsg= "Invalid Format_description log event; could be out of memory"; DBUG_RETURN ((*errmsg) ? 1 : 0); } /** Waits until the SQL thread reaches (has executed up to) the log/position or timed out. SYNOPSIS @param[in] thd client thread that sent @c SELECT @c MASTER_POS_WAIT, @param[in] log_name log name to wait for, @param[in] log_pos position to wait for, @param[in] timeout @c timeout in seconds before giving up waiting. @c timeout is longlong whereas it should be ulong; but this is to catch if the user submitted a negative timeout. @retval -2 improper arguments (log_pos<0) or slave not running, or master info changed during the function's execution, or client thread killed. -2 is translated to NULL by caller, @retval -1 timed out @retval >=0 number of log events the function had to wait before reaching the desired log/position */ int Relay_log_info::wait_for_pos(THD* thd, String* log_name, longlong log_pos, longlong timeout) { int event_count = 0; ulong init_abort_pos_wait; int error=0; struct timespec abstime; // for timeout checking PSI_stage_info old_stage; DBUG_ENTER("Relay_log_info::wait_for_pos"); if (!inited) DBUG_RETURN(-2); DBUG_PRINT("enter",("log_name: '%s' log_pos: %lu timeout: %lu", log_name->c_ptr_safe(), (ulong) log_pos, (ulong) timeout)); set_timespec(abstime,timeout); mysql_mutex_lock(&data_lock); thd->ENTER_COND(&data_cond, &data_lock, &stage_waiting_for_the_slave_thread_to_advance_position, &old_stage); /* This function will abort when it notices that some CHANGE MASTER or RESET MASTER has changed the master info. To catch this, these commands modify abort_pos_wait ; We just monitor abort_pos_wait and see if it has changed. Why do we have this mechanism instead of simply monitoring slave_running in the loop (we do this too), as CHANGE MASTER/RESET SLAVE require that the SQL thread be stopped? This is becasue if someones does: STOP SLAVE;CHANGE MASTER/RESET SLAVE; START SLAVE; the change may happen very quickly and we may not notice that slave_running briefly switches between 1/0/1. */ init_abort_pos_wait= abort_pos_wait; /* We'll need to handle all possible log names comparisons (e.g. 999 vs 1000). We use ulong for string->number conversion ; this is no stronger limitation than in find_uniq_filename in sql/log.cc */ ulong log_name_extension; char log_name_tmp[FN_REFLEN]; //make a char[] from String strmake(log_name_tmp, log_name->ptr(), min<uint32>(log_name->length(), FN_REFLEN-1)); char *p= fn_ext(log_name_tmp); char *p_end; if (!*p || log_pos<0) { error= -2; //means improper arguments goto err; } // Convert 0-3 to 4 log_pos= max<ulong>(log_pos, BIN_LOG_HEADER_SIZE); /* p points to '.' */ log_name_extension= strtoul(++p, &p_end, 10); /* p_end points to the first invalid character. If it equals to p, no digits were found, error. If it contains '\0' it means conversion went ok. */ if (p_end==p || *p_end) { error= -2; goto err; } /* The "compare and wait" main loop */ while (!thd->killed && init_abort_pos_wait == abort_pos_wait && slave_running) { bool pos_reached; int cmp_result= 0; DBUG_PRINT("info", ("init_abort_pos_wait: %ld abort_pos_wait: %ld", init_abort_pos_wait, abort_pos_wait)); DBUG_PRINT("info",("group_master_log_name: '%s' pos: %lu", group_master_log_name, (ulong) group_master_log_pos)); /* group_master_log_name can be "", if we are just after a fresh replication start or after a CHANGE MASTER TO MASTER_HOST/PORT (before we have executed one Rotate event from the master) or (rare) if the user is doing a weird slave setup (see next paragraph). If group_master_log_name is "", we assume we don't have enough info to do the comparison yet, so we just wait until more data. In this case master_log_pos is always 0 except if somebody (wrongly) sets this slave to be a slave of itself without using --replicate-same-server-id (an unsupported configuration which does nothing), then group_master_log_pos will grow and group_master_log_name will stay "". */ if (*group_master_log_name) { char *basename= (group_master_log_name + dirname_length(group_master_log_name)); /* First compare the parts before the extension. Find the dot in the master's log basename, and protect against user's input error : if the names do not match up to '.' included, return error */ char *q= (char*)(fn_ext(basename)+1); if (strncmp(basename, log_name_tmp, (int)(q-basename))) { error= -2; break; } // Now compare extensions. char *q_end; ulong group_master_log_name_extension= strtoul(q, &q_end, 10); if (group_master_log_name_extension < log_name_extension) cmp_result= -1 ; else cmp_result= (group_master_log_name_extension > log_name_extension) ? 1 : 0 ; pos_reached= ((!cmp_result && group_master_log_pos >= (ulonglong)log_pos) || cmp_result > 0); if (pos_reached || thd->killed) break; } //wait for master update, with optional timeout. DBUG_PRINT("info",("Waiting for master update")); /* We are going to mysql_cond_(timed)wait(); if the SQL thread stops it will wake us up. */ thd_wait_begin(thd, THD_WAIT_BINLOG); if (timeout > 0) { /* Note that mysql_cond_timedwait checks for the timeout before for the condition ; i.e. it returns ETIMEDOUT if the system time equals or exceeds the time specified by abstime before the condition variable is signaled or broadcast, _or_ if the absolute time specified by abstime has already passed at the time of the call. For that reason, mysql_cond_timedwait will do the "timeoutting" job even if its condition is always immediately signaled (case of a loaded master). */ error= mysql_cond_timedwait(&data_cond, &data_lock, &abstime); } else mysql_cond_wait(&data_cond, &data_lock); DBUG_PRINT("info",("Got signal of master update or timed out")); if (error == ETIMEDOUT || error == ETIME) { #ifndef DBUG_OFF /* Doing this to generate a stack trace and make debugging easier. */ if (DBUG_EVALUATE_IF("debug_crash_slave_time_out", 1, 0)) DBUG_ASSERT(0); #endif error= -1; break; } error=0; event_count++; DBUG_PRINT("info",("Testing if killed or SQL thread not running")); } err: thd->EXIT_COND(&old_stage); thd_wait_end(thd); DBUG_PRINT("exit",("killed: %d abort: %d slave_running: %d \ improper_arguments: %d timed_out: %d", thd->killed_errno(), (int) (init_abort_pos_wait != abort_pos_wait), (int) slave_running, (int) (error == -2), (int) (error == -1))); if (thd->killed || init_abort_pos_wait != abort_pos_wait || !slave_running) { error= -2; } DBUG_RETURN( error ? error : event_count ); } /* TODO: This is a duplicated code that needs to be simplified. This will be done while developing all possible sync options. See WL#3584's specification. /Alfranio */ int Relay_log_info::wait_for_gtid_set(THD* thd, String* gtid, longlong timeout) { int event_count = 0; ulong init_abort_pos_wait; int error=0; struct timespec abstime; // for timeout checking PSI_stage_info old_stage; DBUG_ENTER("Relay_log_info::wait_for_gtid_set"); if (!inited) DBUG_RETURN(-2); DBUG_PRINT("info", ("Waiting for %s timeout %lld", gtid->c_ptr_safe(), timeout)); set_timespec(abstime, timeout); mysql_mutex_lock(&data_lock); thd->ENTER_COND(&data_cond, &data_lock, &stage_waiting_for_the_slave_thread_to_advance_position, &old_stage); /* This function will abort when it notices that some CHANGE MASTER or RESET MASTER has changed the master info. To catch this, these commands modify abort_pos_wait ; We just monitor abort_pos_wait and see if it has changed. Why do we have this mechanism instead of simply monitoring slave_running in the loop (we do this too), as CHANGE MASTER/RESET SLAVE require that the SQL thread be stopped? This is becasue if someones does: STOP SLAVE;CHANGE MASTER/RESET SLAVE; START SLAVE; the change may happen very quickly and we may not notice that slave_running briefly switches between 1/0/1. */ init_abort_pos_wait= abort_pos_wait; Gtid_set wait_gtid_set(global_sid_map); global_sid_lock->rdlock(); if (wait_gtid_set.add_gtid_text(gtid->c_ptr_safe()) != RETURN_STATUS_OK) { global_sid_lock->unlock(); goto err; } global_sid_lock->unlock(); /* The "compare and wait" main loop */ while (!thd->killed && init_abort_pos_wait == abort_pos_wait && slave_running) { DBUG_PRINT("info", ("init_abort_pos_wait: %ld abort_pos_wait: %ld", init_abort_pos_wait, abort_pos_wait)); //wait for master update, with optional timeout. global_sid_lock->wrlock(); const Gtid_set* logged_gtids= gtid_state->get_logged_gtids(); const Owned_gtids* owned_gtids= gtid_state->get_owned_gtids(); DBUG_PRINT("info", ("Waiting for '%s'. is_subset: %d and " "!is_intersection_nonempty: %d", gtid->c_ptr_safe(), wait_gtid_set.is_subset(logged_gtids), !owned_gtids->is_intersection_nonempty(&wait_gtid_set))); logged_gtids->dbug_print("gtid_executed:"); owned_gtids->dbug_print("owned_gtids:"); /* Since commit is performed after log to binary log, we must also check if any GTID of wait_gtid_set is not yet committed. */ if (wait_gtid_set.is_subset(logged_gtids) && !owned_gtids->is_intersection_nonempty(&wait_gtid_set)) { global_sid_lock->unlock(); break; } global_sid_lock->unlock(); DBUG_PRINT("info",("Waiting for master update")); /* We are going to mysql_cond_(timed)wait(); if the SQL thread stops it will wake us up. */ thd_wait_begin(thd, THD_WAIT_BINLOG); if (timeout > 0) { /* Note that mysql_cond_timedwait checks for the timeout before for the condition ; i.e. it returns ETIMEDOUT if the system time equals or exceeds the time specified by abstime before the condition variable is signaled or broadcast, _or_ if the absolute time specified by abstime has already passed at the time of the call. For that reason, mysql_cond_timedwait will do the "timeoutting" job even if its condition is always immediately signaled (case of a loaded master). */ error= mysql_cond_timedwait(&data_cond, &data_lock, &abstime); } else mysql_cond_wait(&data_cond, &data_lock); DBUG_PRINT("info",("Got signal of master update or timed out")); if (error == ETIMEDOUT || error == ETIME) { #ifndef DBUG_OFF /* Doing this to generate a stack trace and make debugging easier. */ if (DBUG_EVALUATE_IF("debug_crash_slave_time_out", 1, 0)) DBUG_ASSERT(0); #endif error= -1; break; } error=0; event_count++; DBUG_PRINT("info",("Testing if killed or SQL thread not running")); } err: thd->EXIT_COND(&old_stage); thd_wait_end(thd); DBUG_PRINT("exit",("killed: %d abort: %d slave_running: %d \ improper_arguments: %d timed_out: %d", thd->killed_errno(), (int) (init_abort_pos_wait != abort_pos_wait), (int) slave_running, (int) (error == -2), (int) (error == -1))); if (thd->killed || init_abort_pos_wait != abort_pos_wait || !slave_running) { error= -2; } DBUG_RETURN( error ? error : event_count ); } int Relay_log_info::inc_group_relay_log_pos(ulonglong log_pos, bool need_data_lock) { int error= 0; DBUG_ENTER("Relay_log_info::inc_group_relay_log_pos"); if (need_data_lock) mysql_mutex_lock(&data_lock); else mysql_mutex_assert_owner(&data_lock); inc_event_relay_log_pos(); group_relay_log_pos= event_relay_log_pos; strmake(group_relay_log_name,event_relay_log_name, sizeof(group_relay_log_name)-1); notify_group_relay_log_name_update(); /* In 4.x we used the event's len to compute the positions here. This is wrong if the event was 3.23/4.0 and has been converted to 5.0, because then the event's len is not what is was in the master's binlog, so this will make a wrong group_master_log_pos (yes it's a bug in 3.23->4.0 replication: Exec_master_log_pos is wrong). Only way to solve this is to have the original offset of the end of the event the relay log. This is what we do in 5.0: log_pos has become "end_log_pos" (because the real use of log_pos in 4.0 was to compute the end_log_pos; so better to store end_log_pos instead of begin_log_pos. If we had not done this fix here, the problem would also have appeared when the slave and master are 5.0 but with different event length (for example the slave is more recent than the master and features the event UID). It would give false MASTER_POS_WAIT, false Exec_master_log_pos in SHOW SLAVE STATUS, and so the user would do some CHANGE MASTER using this value which would lead to badly broken replication. Even the relay_log_pos will be corrupted in this case, because the len is the relay log is not "val". With the end_log_pos solution, we avoid computations involving lengthes. */ DBUG_PRINT("info", ("log_pos: %lu group_master_log_pos: %lu", (long) log_pos, (long) group_master_log_pos)); if (log_pos > 0) // 3.23 binlogs don't have log_posx group_master_log_pos= log_pos; /* In MTS mode FD or Rotate event commit their solitary group to Coordinator's info table. Callers make sure that Workers have been executed all assignements. Broadcast to master_pos_wait() waiters should be done after the table is updated. */ DBUG_ASSERT(!is_parallel_exec() || mts_group_status != Relay_log_info::MTS_IN_GROUP); /* We do not force synchronization at this point, note the parameter false, because a non-transactional change is being committed. For that reason, the synchronization here is subjected to the option sync_relay_log_info. See sql/rpl_rli.h for further information on this behavior. */ if ((error = flush_info(FALSE))) goto err; /** Gtid_infos need to be flushed only if 1) The current transaction is ended because of a COMMIT or ROLLBACK or XID which can be known by the variable ends_group or 2) If the current event causes an implicit commit which can be determined if the current group didn't see a BEGIN and the current event contains partition info meaning that it is a CREATE DATABASE or DROP DATABASE kind of event. The flush if forced causes performance problems with large number of blackhole inserts. It is just a design choice to force in case of DDL statements. currently ddl are not transactional but if made transactional, the flush to replication tables should be forced. */ if (ends_group && !info_thd->is_enabled_idempotent_recovery() && (error = flush_gtid_infos(false))) goto err; else if (!curr_group_seen_begin && part_event && (error = flush_gtid_infos(true))) goto err; err: mysql_cond_broadcast(&data_cond); if (need_data_lock) mysql_mutex_unlock(&data_lock); DBUG_RETURN(error); } void Relay_log_info::close_temporary_tables() { TABLE *table,*next; DBUG_ENTER("Relay_log_info::close_temporary_tables"); for (table=save_temporary_tables ; table ; table=next) { next=table->next; /* Don't ask for disk deletion. For now, anyway they will be deleted when slave restarts, but it is a better intention to not delete them. */ DBUG_PRINT("info", ("table: 0x%lx", (long) table)); // TODO: Check if we need to have a THD here for slow-query-log close_temporary(NULL, table, 1, 0); } save_temporary_tables= 0; slave_open_temp_tables= 0; DBUG_VOID_RETURN; } /** Purges relay logs. It assumes to have a run lock on rli and that no slave thread are running. @param[in] THD connection, @param[in] just_reset if false, it tells that logs should be purged and @c init_relay_log_pos() should be called, @errmsg[out] errmsg store pointer to an error message. @retval 0 successfuly executed, @retval 1 otherwise error, where errmsg is set to point to the error message. */ int Relay_log_info::purge_relay_logs(THD *thd, bool just_reset, const char** errmsg) { int error=0; DBUG_ENTER("Relay_log_info::purge_relay_logs"); /* Even if inited==0, we still try to empty master_log_* variables. Indeed, inited==0 does not imply that they already are empty. It could be that slave's info initialization partly succeeded: for example if relay-log.info existed but *relay-bin*.* have been manually removed, init_info reads the old relay-log.info and fills rli->master_log_*, then init_info checks for the existence of the relay log, this fails and init_info leaves inited to 0. In that pathological case, master_log_pos* will be properly reinited at the next START SLAVE (as RESET SLAVE or CHANGE MASTER, the callers of purge_relay_logs, will delete bogus *.info files or replace them with correct files), however if the user does SHOW SLAVE STATUS before START SLAVE, he will see old, confusing master_log_*. In other words, we reinit master_log_* for SHOW SLAVE STATUS to display fine in any case. */ group_master_log_name[0]= 0; group_master_log_pos= 0; if (!inited) { DBUG_PRINT("info", ("inited == 0")); DBUG_RETURN(0); } DBUG_ASSERT(slave_running == 0); DBUG_ASSERT(mi->slave_running == 0); slave_skip_counter= 0; mysql_mutex_lock(&data_lock); /* we close the relay log fd possibly left open by the slave SQL thread, to be able to delete it; the relay log fd possibly left open by the slave I/O thread will be closed naturally in reset_logs() by the close(LOG_CLOSE_TO_BE_OPENED) call */ if (cur_log_fd >= 0) { end_io_cache(&cache_buf); my_close(cur_log_fd, MYF(MY_WME)); cur_log_fd= -1; } if (relay_log.reset_logs(thd)) { *errmsg = "Failed during log reset"; error=1; goto err; } /* Save name of used relay log file */ strmake(group_relay_log_name, relay_log.get_log_fname(), sizeof(group_relay_log_name)-1); strmake(event_relay_log_name, relay_log.get_log_fname(), sizeof(event_relay_log_name)-1); group_relay_log_pos= event_relay_log_pos= BIN_LOG_HEADER_SIZE; if (count_relay_log_space()) { *errmsg= "Error counting relay log space"; error= 1; goto err; } if (!just_reset) error= init_relay_log_pos(group_relay_log_name, group_relay_log_pos, false/*need_data_lock=false*/, errmsg, 0); err: #ifndef DBUG_OFF char buf[22]; #endif DBUG_PRINT("info",("log_space_total: %s",llstr(log_space_total,buf))); mysql_mutex_unlock(&data_lock); DBUG_RETURN(error); } /** Checks if condition stated in UNTIL clause of START SLAVE is reached. Specifically, it checks if UNTIL condition is reached. Uses caching result of last comparison of current log file name and target log file name. So cached value should be invalidated if current log file name changes (see @c Relay_log_info::notify_... functions). This caching is needed to avoid of expensive string comparisons and @c strtol() conversions needed for log names comparison. We don't need to compare them each time this function is called, we only need to do this when current log name changes. If we have @c UNTIL_MASTER_POS condition we need to do this only after @c Rotate_log_event::do_apply_event() (which is rare, so caching gives real benifit), and if we have @c UNTIL_RELAY_POS condition then we should invalidate cached comarison value after @c inc_group_relay_log_pos() which called for each group of events (so we have some benefit if we have something like queries that use autoincrement or if we have transactions). Should be called ONLY if @c until_condition @c != @c UNTIL_NONE ! @param master_beg_pos position of the beginning of to be executed event (not @c log_pos member of the event that points to the beginning of the following event) @retval true condition met or error happened (condition seems to have bad log file name), @retval false condition not met. */ bool Relay_log_info::is_until_satisfied(THD *thd, Log_event *ev) { char error_msg[]= "Slave SQL thread is stopped because UNTIL " "condition is bad."; DBUG_ENTER("Relay_log_info::is_until_satisfied"); switch (until_condition) { case UNTIL_MASTER_POS: case UNTIL_RELAY_POS: { const char *log_name= NULL; ulonglong log_pos= 0; if (until_condition == UNTIL_MASTER_POS) { if (ev && ev->server_id == (uint32) ::server_id && !replicate_same_server_id) DBUG_RETURN(false); log_name= group_master_log_name; log_pos= (!ev || is_in_group() || !ev->log_pos) ? group_master_log_pos : ev->log_pos - ev->data_written; } else { /* until_condition == UNTIL_RELAY_POS */ log_name= group_relay_log_name; log_pos= group_relay_log_pos; } #ifndef DBUG_OFF { char buf[32]; DBUG_PRINT("info", ("group_master_log_name='%s', group_master_log_pos=%s", group_master_log_name, llstr(group_master_log_pos, buf))); DBUG_PRINT("info", ("group_relay_log_name='%s', group_relay_log_pos=%s", group_relay_log_name, llstr(group_relay_log_pos, buf))); DBUG_PRINT("info", ("(%s) log_name='%s', log_pos=%s", until_condition == UNTIL_MASTER_POS ? "master" : "relay", log_name, llstr(log_pos, buf))); DBUG_PRINT("info", ("(%s) until_log_name='%s', until_log_pos=%s", until_condition == UNTIL_MASTER_POS ? "master" : "relay", until_log_name, llstr(until_log_pos, buf))); } #endif if (until_log_names_cmp_result == UNTIL_LOG_NAMES_CMP_UNKNOWN) { /* We have no cached comparison results so we should compare log names and cache result. If we are after RESET SLAVE, and the SQL slave thread has not processed any event yet, it could be that group_master_log_name is "". In that case, just wait for more events (as there is no sensible comparison to do). */ if (*log_name) { const char *basename= log_name + dirname_length(log_name); const char *q= (const char*)(fn_ext(basename)+1); if (strncmp(basename, until_log_name, (int)(q-basename)) == 0) { /* Now compare extensions. */ char *q_end; ulong log_name_extension= strtoul(q, &q_end, 10); if (log_name_extension < until_log_name_extension) until_log_names_cmp_result= UNTIL_LOG_NAMES_CMP_LESS; else until_log_names_cmp_result= (log_name_extension > until_log_name_extension) ? UNTIL_LOG_NAMES_CMP_GREATER : UNTIL_LOG_NAMES_CMP_EQUAL ; } else { /* Base names do not match, so we abort */ sql_print_error("%s", error_msg); DBUG_RETURN(true); } } else DBUG_RETURN(until_log_pos == 0); } if (((until_log_names_cmp_result == UNTIL_LOG_NAMES_CMP_EQUAL && log_pos >= until_log_pos) || until_log_names_cmp_result == UNTIL_LOG_NAMES_CMP_GREATER)) { char buf[22]; sql_print_information("Slave SQL thread stopped because it reached its" " UNTIL position %s", llstr(until_pos(), buf)); DBUG_RETURN(true); } DBUG_RETURN(false); } case UNTIL_SQL_BEFORE_GTIDS: // We only need to check once if logged_gtids set contains any of the until_sql_gtids. if (until_sql_gtids_first_event) { until_sql_gtids_first_event= false; global_sid_lock->wrlock(); /* Check if until GTIDs were already applied. */ const Gtid_set* logged_gtids= gtid_state->get_logged_gtids(); if (until_sql_gtids.is_intersection_nonempty(logged_gtids)) { char *buffer= until_sql_gtids.to_string(); global_sid_lock->unlock(); sql_print_information("Slave SQL thread stopped because " "UNTIL SQL_BEFORE_GTIDS %s is already " "applied", buffer); my_free(buffer); DBUG_RETURN(true); } global_sid_lock->unlock(); } if (ev != NULL && ev->get_type_code() == GTID_LOG_EVENT) { Gtid_log_event *gev= (Gtid_log_event *)ev; global_sid_lock->rdlock(); if (until_sql_gtids.contains_gtid(gev->get_sidno(false), gev->get_gno())) { char *buffer= until_sql_gtids.to_string(); global_sid_lock->unlock(); sql_print_information("Slave SQL thread stopped because it reached " "UNTIL SQL_BEFORE_GTIDS %s", buffer); my_free(buffer); DBUG_RETURN(true); } global_sid_lock->unlock(); } DBUG_RETURN(false); break; case UNTIL_SQL_AFTER_GTIDS: { global_sid_lock->wrlock(); const Gtid_set* logged_gtids= gtid_state->get_logged_gtids(); if (until_sql_gtids.is_subset(logged_gtids)) { char *buffer= until_sql_gtids.to_string(); global_sid_lock->unlock(); sql_print_information("Slave SQL thread stopped because it reached " "UNTIL SQL_AFTER_GTIDS %s", buffer); my_free(buffer); DBUG_RETURN(true); } global_sid_lock->unlock(); DBUG_RETURN(false); } break; case UNTIL_SQL_AFTER_MTS_GAPS: case UNTIL_DONE: /* TODO: this condition is actually post-execution or post-scheduling so the proper place to check it before SQL thread goes into next_event() where it can wait while the condition has been satisfied already. It's deployed here temporarily to be fixed along the regular UNTIL support for MTS is provided. */ if (mts_recovery_group_cnt == 0) { sql_print_information("Slave SQL thread stopped according to " "UNTIL SQL_AFTER_MTS_GAPS as it has " "processed all gap transactions left from " "the previous slave session."); until_condition= UNTIL_DONE; DBUG_RETURN(true); } else { DBUG_RETURN(false); } break; case UNTIL_NONE: DBUG_ASSERT(0); break; } DBUG_ASSERT(0); DBUG_RETURN(false); } void Relay_log_info::cached_charset_invalidate() { DBUG_ENTER("Relay_log_info::cached_charset_invalidate"); /* Full of zeroes means uninitialized. */ memset(cached_charset, 0, sizeof(cached_charset)); DBUG_VOID_RETURN; } bool Relay_log_info::cached_charset_compare(char *charset) const { DBUG_ENTER("Relay_log_info::cached_charset_compare"); if (memcmp(cached_charset, charset, sizeof(cached_charset))) { memcpy(const_cast<char*>(cached_charset), charset, sizeof(cached_charset)); DBUG_RETURN(1); } DBUG_RETURN(0); } int Relay_log_info::stmt_done(my_off_t event_master_log_pos) { int error= 0; clear_flag(IN_STMT); DBUG_ASSERT(!belongs_to_client()); /* Worker does not execute binlog update position logics */ DBUG_ASSERT(!is_mts_worker(info_thd)); /* Replication keeps event and group positions to specify the set of events that were executed. Event positions are incremented after processing each event whereas group positions are incremented when an event or a set of events is processed such as in a transaction and are committed or rolled back. A transaction can be ended with a Query Event, i.e. either commit or rollback, or by a Xid Log Event. Query Event is used to terminate pseudo-transactions that are executed against non-transactional engines such as MyIsam. Xid Log Event denotes though that a set of changes executed against a transactional engine is about to commit. Events' positions are incremented at stmt_done(). However, transactions that are ended with Xid Log Event have their group position incremented in the do_apply_event() and in the do_apply_event_work(). Notice that the type of the engine, i.e. where data and positions are stored, against what events are being applied are not considered in this logic. Regarding the code that follows, notice that the executed group coordinates don't change if the current event is internal to the group. The same applies to MTS Coordinator when it handles a Format Descriptor event that appears in the middle of a group that is about to be assigned. */ if ((!is_parallel_exec() && is_in_group()) || mts_group_status != MTS_NOT_IN_GROUP) { inc_event_relay_log_pos(); } else { if (is_parallel_exec()) { DBUG_ASSERT(!is_mts_worker(info_thd)); /* Format Description events only can drive MTS execution to this point. It is a special event group that is handled with synchronization. For that reason, the checkpoint routine is called here. */ error= mts_checkpoint_routine(this, 0, false, true/*need_data_lock=true*/); } if (!error) error= inc_group_relay_log_pos(event_master_log_pos, true/*need_data_lock=true*/); } return error; } #if !defined(MYSQL_CLIENT) && defined(HAVE_REPLICATION) void Relay_log_info::cleanup_context(THD *thd, bool error) { DBUG_ENTER("Relay_log_info::cleanup_context"); DBUG_ASSERT(info_thd == thd); /* 1) Instances of Table_map_log_event, if ::do_apply_event() was called on them, may have opened tables, which we cannot be sure have been closed (because maybe the Rows_log_event have not been found or will not be, because slave SQL thread is stopping, or relay log has a missing tail etc). So we close all thread's tables. And so the table mappings have to be cancelled. 2) Rows_log_event::do_apply_event() may even have started statements or transactions on them, which we need to rollback in case of error. 3) If finding a Format_description_log_event after a BEGIN, we also need to rollback before continuing with the next events. 4) so we need this "context cleanup" function. */ if (error) { trans_rollback_stmt(thd); // if a "statement transaction" trans_rollback(thd); // if a "real transaction" } if (rows_query_ev) { delete rows_query_ev; rows_query_ev= NULL; info_thd->set_query(NULL, 0); } m_table_map.clear_tables(); slave_close_thread_tables(thd); if (error) thd->mdl_context.release_transactional_locks(); clear_flag(IN_STMT); /* Cleanup for the flags that have been set at do_apply_event. */ thd->variables.option_bits&= ~OPTION_NO_FOREIGN_KEY_CHECKS; thd->variables.option_bits&= ~OPTION_RELAXED_UNIQUE_CHECKS; /* Reset state related to long_find_row notes in the error log: - timestamp - flag that decides whether the slave prints or not */ reset_row_stmt_start_timestamp(); unset_long_find_row_note_printed(); DBUG_VOID_RETURN; } void Relay_log_info::clear_tables_to_lock() { DBUG_ENTER("Relay_log_info::clear_tables_to_lock()"); #ifndef DBUG_OFF /** When replicating in RBR and MyISAM Merge tables are involved open_and_lock_tables (called in do_apply_event) appends the base tables to the list of tables_to_lock. Then these are removed from the list in close_thread_tables (which is called before we reach this point). This assertion just confirms that we get no surprises at this point. */ uint i=0; for (TABLE_LIST *ptr= tables_to_lock ; ptr ; ptr= ptr->next_global, i++) ; DBUG_ASSERT(i == tables_to_lock_count); #endif while (tables_to_lock) { uchar* to_free= reinterpret_cast<uchar*>(tables_to_lock); if (tables_to_lock->m_tabledef_valid) { tables_to_lock->m_tabledef.table_def::~table_def(); tables_to_lock->m_tabledef_valid= FALSE; } /* If blob fields were used during conversion of field values from the master table into the slave table, then we need to free the memory used temporarily to store their values before copying into the slave's table. */ if (tables_to_lock->m_conv_table) free_blobs(tables_to_lock->m_conv_table); tables_to_lock= static_cast<RPL_TABLE_LIST*>(tables_to_lock->next_global); tables_to_lock_count--; my_free(to_free); } DBUG_ASSERT(tables_to_lock == NULL && tables_to_lock_count == 0); DBUG_VOID_RETURN; } void Relay_log_info::slave_close_thread_tables(THD *thd) { thd->get_stmt_da()->set_overwrite_status(true); DBUG_ENTER("Relay_log_info::slave_close_thread_tables(THD *thd)"); thd->is_error() ? trans_rollback_stmt(thd) : trans_commit_stmt(thd); thd->get_stmt_da()->set_overwrite_status(false); close_thread_tables(thd); /* - If transaction rollback was requested due to deadlock perform it and release metadata locks. - If inside a multi-statement transaction, defer the release of metadata locks until the current transaction is either committed or rolled back. This prevents other statements from modifying the table for the entire duration of this transaction. This provides commit ordering and guarantees serializability across multiple transactions. - If in autocommit mode, or outside a transactional context, automatically release metadata locks of the current statement. */ if (thd->transaction_rollback_request) { trans_rollback_implicit(thd); thd->mdl_context.release_transactional_locks(); } else if (! thd->in_multi_stmt_transaction_mode()) thd->mdl_context.release_transactional_locks(); else thd->mdl_context.release_statement_locks(); clear_tables_to_lock(); DBUG_VOID_RETURN; } /** Execute a SHOW RELAYLOG EVENTS statement. @param thd Pointer to THD object for the client thread executing the statement. @retval FALSE success @retval TRUE failure */ bool mysql_show_relaylog_events(THD* thd) { Protocol *protocol= thd->protocol; List<Item> field_list; DBUG_ENTER("mysql_show_relaylog_events"); DBUG_ASSERT(thd->lex->sql_command == SQLCOM_SHOW_RELAYLOG_EVENTS); Log_event::init_show_field_list(&field_list); if (protocol->send_result_set_metadata(&field_list, Protocol::SEND_NUM_ROWS | Protocol::SEND_EOF)) DBUG_RETURN(TRUE); if (active_mi == NULL) { my_error(ER_SLAVE_CONFIGURATION, MYF(0)); DBUG_RETURN(true); } DBUG_RETURN(show_binlog_events(thd, &active_mi->rli->relay_log)); } #endif int Relay_log_info::rli_init_info(bool startup) { int error= 0; enum_return_check check_return= ERROR_CHECKING_REPOSITORY; const char *msg= NULL; DBUG_ENTER("Relay_log_info::rli_init_info"); mysql_mutex_assert_owner(&data_lock); /* If Relay_log_info is issued again after a failed init_info(), for instance because of missing relay log files, it will generate new files and ignore the previous failure, to avoid that we set error_on_rli_init_info as true. This a consequence of the behaviour change, in the past server was stopped when there were replication initialization errors, now it is not and so init_info() must be aware of previous failures. */ if (error_on_rli_init_info) { // In raft mode, these error codes are critical. Hence we should // not chew them. if (!startup && enable_raft_plugin) { error= 1; } goto err; } if (inited) { /* We have to reset read position of relay-log-bin as we may have already been reading from 'hotlog' when the slave was stopped last time. If this case pos_in_file would be set and we would get a crash when trying to read the signature for the binary relay log. We only rewind the read position if we are starting the SQL thread. The handle_slave_sql thread assumes that the read position is at the beginning of the file, and will read the "signature" and then fast-forward to the last position read. */ bool hot_log= FALSE; /* my_b_seek does an implicit flush_io_cache, so we need to: 1. check if this log is active (hot) 2. if it is we keep log_lock until the seek ends, otherwise release it right away. If we did not take log_lock, SQL thread might race with IO thread for the IO_CACHE mutex. */ mysql_mutex_t *log_lock= relay_log.get_log_lock(); mysql_mutex_lock(log_lock); hot_log= relay_log.is_active(linfo.log_file_name); if (!hot_log) mysql_mutex_unlock(log_lock); // In raft mode we re-init the IO_CACHE because the relay log (raft log) // might be truncated later if (enable_raft_plugin && hot_log) { File file= cur_log->file; size_t len= cur_log->buffer_length; enum cache_type type= cur_log->type; myf flags= cur_log->myflags; if (end_io_cache(cur_log) == 0 && init_io_cache(cur_log, file, len, type, 0, 0, flags) == 0) { sql_print_information( "Reinited relay log to handle potential raft log truncation"); } else { error= 1; sql_print_error( "Error while reiniting relay log to handle potential raft log " "truncation"); } } else my_b_seek(cur_log, (my_off_t) 0); if (hot_log) mysql_mutex_unlock(log_lock); if (error) DBUG_RETURN(1); DBUG_RETURN((gtid_mode == 0 && recovery_parallel_workers) ? mts_recovery_groups(this) : 0); } cur_log_fd = -1; slave_skip_counter= 0; abort_pos_wait= 0; log_space_limit= relay_log_space_limit; log_space_total= 0; tables_to_lock= 0; tables_to_lock_count= 0; char pattern[FN_REFLEN]; (void) my_realpath(pattern, slave_load_tmpdir, 0); if (fn_format(pattern, PREFIX_SQL_LOAD, pattern, "", MY_SAFE_PATH | MY_RETURN_REAL_PATH) == NullS) { sql_print_error("Unable to use slave's temporary directory '%s'.", slave_load_tmpdir); DBUG_RETURN(1); } unpack_filename(slave_patternload_file, pattern); slave_patternload_file_size= strlen(slave_patternload_file); /* The relay log will now be opened, as a SEQ_READ_APPEND IO_CACHE. Note that the I/O thread flushes it to disk after writing every event, in flush_info within the master info. */ /* For the maximum log size, we choose max_relay_log_size if it is non-zero, max_binlog_size otherwise. If later the user does SET GLOBAL on one of these variables, fix_max_binlog_size and fix_max_relay_log_size will reconsider the choice (for example if the user changes max_relay_log_size to zero, we have to switch to using max_binlog_size for the relay log) and update relay_log.max_size (and mysql_bin_log.max_size). */ { /* Reports an error and returns, if the --relay-log's path is a directory.*/ if (opt_relay_logname && opt_relay_logname[strlen(opt_relay_logname) - 1] == FN_LIBCHAR) { sql_print_error("Path '%s' is a directory name, please specify \ a file name for --relay-log option.", opt_relay_logname); DBUG_RETURN(1); } /* Reports an error and returns, if the --relay-log-index's path is a directory.*/ if (opt_relaylog_index_name && opt_relaylog_index_name[strlen(opt_relaylog_index_name) - 1] == FN_LIBCHAR) { sql_print_error("Path '%s' is a directory name, please specify \ a file name for --relay-log-index option.", opt_relaylog_index_name); DBUG_RETURN(1); } char buf[FN_REFLEN]; const char *ln; static bool name_warning_sent= 0; // In raft mode, relay log always points to the raft log (which is the // binlog) char* relay_log_index_name= opt_relaylog_index_name; if (enable_raft_plugin) { ln= relay_log.generate_name(opt_bin_logname, "-bin", 1, buf); relay_log_index_name= opt_binlog_index_name; } else ln= relay_log.generate_name(opt_relay_logname, "-relay-bin", 1, buf); /* We send the warning only at startup, not after every RESET SLAVE */ if (!opt_relay_logname && !opt_relaylog_index_name && !name_warning_sent) { /* User didn't give us info to name the relay log index file. Picking `hostname`-relay-bin.index like we do, causes replication to fail if this slave's hostname is changed later. So, we would like to instead require a name. But as we don't want to break many existing setups, we only give warning, not error. */ sql_print_warning("Neither --relay-log nor --relay-log-index were used;" " so replication " "may break when this MySQL server acts as a " "slave and has his hostname changed!! Please " "use '--relay-log=%s' to avoid this problem.", ln); name_warning_sent= 1; } relay_log.is_relay_log= TRUE; // if opt_relay_logname and opt_relaylog_index_name are both unset, // the server should crash at this point if (relay_log.open_index_file(relay_log_index_name, ln, TRUE)) { sql_print_error("Failed in open_index_file() called from Relay_log_info::rli_init_info()."); DBUG_RETURN(1); } /* Remove entries of logs from the index that were deleted from the file system but not from the index due to a crash. */ if (relay_log.remove_deleted_logs_from_index(TRUE, FALSE) == LOG_INFO_IO) { sql_print_error("Failed in remove_deleted_logs_from_index()" " called from Relay_log_info::rli_init_info()."); DBUG_RETURN(1); } if (enable_raft_plugin && startup) { // recover relay/raft logs on mysqld startup. This is to remove partial // trxs from the log if (relay_log.recover_raft_log()) { // TODO: Ignoring error for now. Will change the behavior once validated // NO_LINT_DEBUG sql_print_information("Failed to recover raft logs"); } } #ifndef DBUG_OFF global_sid_lock->wrlock(); gtid_set.dbug_print("set of GTIDs in relay log before initialization"); global_sid_lock->unlock(); #endif /* Below init_gtid_sets() function will parse the available relay logs and set I/O retrieved gtid event in gtid_state object. We dont need to find last_retrieved_gtid_event if relay_log_recovery=1 (retrieved set will be cleared off in that case). */ if (!current_thd && relay_log.init_gtid_sets(&gtid_set, NULL, is_relay_log_recovery ? NULL : get_last_retrieved_gtid(), opt_slave_sql_verify_checksum, true/*true=need lock*/)) { sql_print_error("Failed in init_gtid_sets() called from Relay_log_info::rli_init_info()."); DBUG_RETURN(1); } #ifndef DBUG_OFF global_sid_lock->wrlock(); gtid_set.dbug_print("set of GTIDs in relay log after initialization"); global_sid_lock->unlock(); #endif /* Configures what object is used by the current log to store processed gtid(s). This is necessary in the MYSQL_BIN_LOG::MYSQL_BIN_LOG to corretly compute the set of previous gtids. */ relay_log.set_previous_gtid_set(&gtid_set); /* note, that if open() fails, we'll still have index file open but a destructor will take care of that */ if (enable_raft_plugin) { if (relay_log.open_existing_binlog( opt_bin_logname, SEQ_READ_APPEND, max_binlog_size)) { // NO_LINT_DEBUG sql_print_error("Failed to open existing binlog called from " "Relay_log_info::rli_init_info()."); DBUG_RETURN(1); } } else { if (relay_log.open_binlog(ln, 0, SEQ_READ_APPEND, (max_relay_log_size ? max_relay_log_size : max_binlog_size), true, true/*need_lock_index=true*/, true/*need_sid_lock=true*/, mi->get_mi_description_event())) { // NO_LINT_DEBUG sql_print_error("Failed in open_log() called from " "Relay_log_info::rli_init_info()."); DBUG_RETURN(1); } } } /* This checks if the repository was created before and thus there will be values to be read. Please, do not move this call after the handler->init_info(). */ if ((check_return= check_info()) == ERROR_CHECKING_REPOSITORY) { msg= "Error checking relay log repository"; error= 1; goto err; } if (handler->init_info()) { msg= "Error reading relay log configuration"; error= 1; goto err; } if (check_return == REPOSITORY_DOES_NOT_EXIST) { /* Init relay log with first entry in the relay index file */ if (init_relay_log_pos(NullS, BIN_LOG_HEADER_SIZE, false/*need_data_lock=false (lock should be held prior to invoking this function)*/, &msg, 0)) { error= 1; goto err; } group_master_log_name[0]= 0; group_master_log_pos= 0; } else { if (read_info(handler)) { msg= "Error reading relay log configuration"; error= 1; goto err; } if (is_relay_log_recovery && init_recovery(mi, &msg)) { error= 1; goto err; } if (init_relay_log_pos(group_relay_log_name, group_relay_log_pos, false/*need_data_lock=false (lock should be held prior to invoking this function)*/, &msg, 0)) { char llbuf[22]; sql_print_error("Failed to open the relay log '%s' (relay_log_pos %s).", group_relay_log_name, llstr(group_relay_log_pos, llbuf)); error= 1; goto err; } #ifndef DBUG_OFF { char llbuf1[22], llbuf2[22]; DBUG_PRINT("info", ("my_b_tell(cur_log)=%s event_relay_log_pos=%s", llstr(my_b_tell(cur_log),llbuf1), llstr(event_relay_log_pos,llbuf2))); DBUG_ASSERT(event_relay_log_pos >= BIN_LOG_HEADER_SIZE); DBUG_ASSERT((my_b_tell(cur_log) == event_relay_log_pos)); } #endif } inited= 1; error_on_rli_init_info= false; if (flush_info(TRUE)) { msg= "Error reading relay log configuration"; error= 1; goto err; } if (count_relay_log_space()) { msg= "Error counting relay log space"; error= 1; goto err; } /* In case of MTS the recovery is deferred until the end of global_init_info. */ if (!mi->rli->mts_recovery_group_cnt) is_relay_log_recovery= FALSE; DBUG_RETURN(error); err: handler->end_info(); inited= 0; error_on_rli_init_info= true; if (msg) sql_print_error("%s.", msg); relay_log.close(LOG_CLOSE_INDEX | LOG_CLOSE_STOP_EVENT); DBUG_RETURN(error); } int Relay_log_info::add_logged_gtid(const std::string &logged_gtid) { Gtid gtid; global_sid_lock->assert_some_lock(); auto status = gtid.parse(global_sid_map, logged_gtid.c_str()); if (status != RETURN_STATUS_OK) { return 1; } gtid_set.ensure_sidno(gtid.sidno); gtid_set._add_gtid(gtid.sidno, gtid.gno); return 0; } int Relay_log_info::remove_logged_gtids( const std::vector<std::string>& trimmed_gtids) { DBUG_ENTER("Relay_log_info::remove_logged_gtid"); global_sid_lock->assert_some_lock(); if (trimmed_gtids.empty()) RETURN_OK; Gtid gtid; for (const auto& trimmed_gtid : trimmed_gtids) { auto status = gtid.parse(global_sid_map, trimmed_gtid.c_str()); if (status != RETURN_STATUS_OK) { // NO_LINT_DEBUG sql_print_error("Failed to parse gtid %s", trimmed_gtid.c_str()); RETURN_REPORTED_ERROR; } if (gtid.sidno > 0) { /* Remove Gtid from logged_gtid set. */ DBUG_PRINT( "info", ("Removing gtid(sidno:%d, gno:%lld) from rli logged gtids", gtid.sidno, gtid.gno)); if (gtid_set._remove_gtid(gtid) != RETURN_STATUS_OK) { // NO_LINT_DEBUG sql_print_error("Failed to remove gtid(sidno:%d, gno: %lld) from " "rli logged gtids. ", gtid.sidno, gtid.gno); RETURN_REPORTED_ERROR; } } } RETURN_OK; } void Relay_log_info::end_info() { DBUG_ENTER("Relay_log_info::end_info"); error_on_rli_init_info= false; if (!inited) DBUG_VOID_RETURN; handler->end_info(); if (cur_log_fd >= 0) { end_io_cache(&cache_buf); (void)my_close(cur_log_fd, MYF(MY_WME)); cur_log_fd= -1; } inited = 0; relay_log.close(LOG_CLOSE_INDEX | LOG_CLOSE_STOP_EVENT); relay_log.harvest_bytes_written(this, true/*need_log_space_lock=true*/); /* Delete the slave's temporary tables from memory. In the future there will be other actions than this, to ensure persistance of slave's temp tables after shutdown. */ close_temporary_tables(); my_hash_reset(&map_db_to_gtid_info); DBUG_VOID_RETURN; } int Relay_log_info::flush_current_log() { DBUG_ENTER("Relay_log_info::flush_current_log"); /* When we come to this place in code, relay log may or not be initialized; the caller is responsible for setting 'flush_relay_log_cache' accordingly. */ IO_CACHE *log_file= relay_log.get_log_file(); if (flush_io_cache(log_file)) DBUG_RETURN(2); DBUG_RETURN(0); } void Relay_log_info::set_master_info(Master_info* info) { mi= info; } /** Stores the file and position where the execute-slave thread are in the relay log: - As this is only called by the slave thread or on STOP SLAVE, with the log_lock grabbed and the slave thread stopped, we don't need to have a lock here. - If there is an active transaction, then we don't update the position in the relay log. This is to ensure that we re-execute statements if we die in the middle of an transaction that was rolled back. - As a transaction never spans binary logs, we don't have to handle the case where we do a relay-log-rotation in the middle of the transaction. If this would not be the case, we would have to ensure that we don't delete the relay log file where the transaction started when we switch to a new relay log file. @retval 0 ok, @retval 1 write error, otherwise. */ /** Store the file and position where the slave's SQL thread are in the relay log. Notes: - This function should be called either from the slave SQL thread, or when the slave thread is not running. (It reads the group_{relay|master}_log_{pos|name} and delay fields in the rli object. These may only be modified by the slave SQL thread or by a client thread when the slave SQL thread is not running.) - If there is an active transaction, then we do not update the position in the relay log. This is to ensure that we re-execute statements if we die in the middle of an transaction that was rolled back. - As a transaction never spans binary logs, we don't have to handle the case where we do a relay-log-rotation in the middle of the transaction. If transactions could span several binlogs, we would have to ensure that we do not delete the relay log file where the transaction started before switching to a new relay log file. - Error can happen if writing to file fails or if flushing the file fails. @param rli The object representing the Relay_log_info. @todo Change the log file information to a binary format to avoid calling longlong2str. @return 0 on success, 1 on error. */ int Relay_log_info::flush_info(const bool force) { DBUG_ENTER("Relay_log_info::flush_info"); if (!inited) DBUG_RETURN(0); /* We update the sync_period at this point because only here we now that we are handling a relay log info. This needs to be update every time we call flush because the option maybe dinamically set. */ handler->set_sync_period(sync_relayloginfo_period); #if defined(FLUSH_REP_INFO) if (!handler->need_write(force)) DBUG_RETURN(0); #endif if (write_info(handler)) goto err; if (handler->flush_info(force || force_flush_postponed_due_to_split_trans)) goto err; force_flush_postponed_due_to_split_trans= false; DBUG_RETURN(0); err: sql_print_error("Error writing relay log configuration."); DBUG_RETURN(1); } size_t Relay_log_info::get_number_info_rli_fields() { return sizeof(info_rli_fields)/sizeof(info_rli_fields[0]); } bool Relay_log_info::read_info(Rpl_info_handler *from) { int lines= 0; char *first_non_digit= NULL; ulong temp_group_relay_log_pos= 0; ulong temp_group_master_log_pos= 0; int temp_sql_delay= 0; int temp_internal_id= internal_id; DBUG_ENTER("Relay_log_info::read_info"); /* Should not read RLI from file in client threads. Client threads only use RLI to execute BINLOG statements. @todo Uncomment the following assertion. Currently, Relay_log_info::init() is called from init_master_info() before the THD object Relay_log_info::sql_thd is created. That means we cannot call belongs_to_client() since belongs_to_client() dereferences Relay_log_info::sql_thd. So we need to refactor slightly: the THD object should be created by Relay_log_info constructor (or passed to it), so that we are guaranteed that it exists at this point. /Sven */ //DBUG_ASSERT(!belongs_to_client()); /* Starting from 5.1.x, relay-log.info has a new format. Now, its first line contains the number of lines in the file. By reading this number we can determine which version our master.info comes from. We can't simply count the lines in the file, since versions before 5.1.x could generate files with more lines than needed. If first line doesn't contain a number, or if it contains a number less than LINES_IN_RELAY_LOG_INFO_WITH_DELAY, then the file is treated like a file from pre-5.1.x version. There is no ambiguity when reading an old master.info: before 5.1.x, the first line contained the binlog's name, which is either empty or has an extension (contains a '.'), so can't be confused with an integer. So we're just reading first line and trying to figure which version is this. */ /* The first row is temporarily stored in mi->master_log_name, if it is line count and not binlog name (new format) it will be overwritten by the second row later. */ if (from->prepare_info_for_read() || from->get_info(group_relay_log_name, (size_t) sizeof(group_relay_log_name), (char *) "")) DBUG_RETURN(TRUE); lines= strtoul(group_relay_log_name, &first_non_digit, 10); if (group_relay_log_name[0]!='\0' && *first_non_digit=='\0' && lines >= LINES_IN_RELAY_LOG_INFO_WITH_DELAY) { /* Seems to be new format => read group relay log name */ if (from->get_info(group_relay_log_name, (size_t) sizeof(group_relay_log_name), (char *) "")) DBUG_RETURN(TRUE); } else DBUG_PRINT("info", ("relay_log_info file is in old format.")); if (from->get_info((ulong *) &temp_group_relay_log_pos, (ulong) BIN_LOG_HEADER_SIZE) || from->get_info(group_master_log_name, (size_t) sizeof(group_relay_log_name), (char *) "") || from->get_info((ulong *) &temp_group_master_log_pos, (ulong) 0)) DBUG_RETURN(TRUE); if (lines >= LINES_IN_RELAY_LOG_INFO_WITH_DELAY) { if (from->get_info((int *) &temp_sql_delay, (int) 0)) DBUG_RETURN(TRUE); } if (lines >= LINES_IN_RELAY_LOG_INFO_WITH_WORKERS) { if (from->get_info(&recovery_parallel_workers,(ulong) 0)) DBUG_RETURN(TRUE); } if (lines >= LINES_IN_RELAY_LOG_INFO_WITH_ID) { if (from->get_info(&temp_internal_id, (int) 1)) DBUG_RETURN(TRUE); } group_relay_log_pos= temp_group_relay_log_pos; group_master_log_pos= temp_group_master_log_pos; sql_delay= (int32) temp_sql_delay; internal_id= (uint) temp_internal_id; DBUG_ASSERT(lines < LINES_IN_RELAY_LOG_INFO_WITH_ID || (lines >= LINES_IN_RELAY_LOG_INFO_WITH_ID && internal_id == 1)); DBUG_RETURN(FALSE); } bool Relay_log_info::write_info(Rpl_info_handler *to) { DBUG_ENTER("Relay_log_info::write_info"); /* @todo Uncomment the following assertion. See todo in Relay_log_info::read_info() for details. /Sven */ //DBUG_ASSERT(!belongs_to_client()); if (to->prepare_info_for_write()) DBUG_RETURN(TRUE); if (to->get_rpl_info_type() != INFO_REPOSITORY_FILE) { if (to->set_info((int) LINES_IN_RELAY_LOG_INFO_WITH_ID) || to->set_info(group_relay_log_name) || to->set_info((ulong) group_relay_log_pos) || to->set_info(group_master_log_name) || to->set_info((ulong) group_master_log_pos) || to->set_info((int) sql_delay) || to->set_info(recovery_parallel_workers) || to->set_info((int) internal_id)) DBUG_RETURN(TRUE); } else { if (to->set_info(LINES_IN_RELAY_LOG_INFO_WITH_ID, "%d\n%s\n%lu\n%s\n%lu\n%d\n%lu\n%d\n", (int) LINES_IN_RELAY_LOG_INFO_WITH_ID, group_relay_log_name, (ulong) group_relay_log_pos, group_master_log_name, (ulong) group_master_log_pos, (int) sql_delay, recovery_parallel_workers, (int) internal_id)) DBUG_RETURN(TRUE); } DBUG_RETURN(FALSE); } /** Delete the existing event and set a new one. This class is responsible for freeing the event, the caller should not do that. When a new FD is from the master adaptation routine is invoked to align the slave applier execution context with the master version. The method is run by SQL thread/MTS Coordinator. Although notice that MTS worker runs it, inefficiently (see assert), once at its destruction time. todo: fix Slave_worker and Relay_log_info inheritance relation. @param a pointer to be installed into execution context FormatDescriptor event */ void Relay_log_info::set_rli_description_event(Format_description_log_event *fe) { DBUG_ASSERT(!info_thd || !is_mts_worker(info_thd) || !fe); if (fe) { adapt_to_master_version(fe); if (info_thd && is_parallel_exec()) { for (uint i= 0; i < workers.elements; i++) { Slave_worker *w= *(Slave_worker **) dynamic_array_ptr(&workers, i); mysql_mutex_lock(&w->jobs_lock); if (w->running_status == Slave_worker::RUNNING) w->set_rli_description_event(fe); mysql_mutex_unlock(&w->jobs_lock); } } } delete rli_description_event; rli_description_event= fe; } struct st_feature_version { /* The enum must be in the version non-descending top-down order, the last item formally corresponds to highest possible server version (never reached, thereby no adapting actions here); enumeration starts from zero. */ enum { WL6292_TIMESTAMP_EXPLICIT_DEFAULT= 0, _END_OF_LIST // always last } item; /* Version where the feature is introduced. */ uchar version_split[3]; /* Action to perform when according to FormatDescriptor event Master is found to be feature-aware while previously it has *not* been. */ void (*upgrade) (THD*); /* Action to perform when according to FormatDescriptor event Master is found to be feature-*un*aware while previously it has been. */ void (*downgrade) (THD*); }; void wl6292_upgrade_func(THD *thd) { thd->variables.explicit_defaults_for_timestamp= false; if (global_system_variables.explicit_defaults_for_timestamp) thd->variables.explicit_defaults_for_timestamp= true; return; } void wl6292_downgrade_func(THD *thd) { if (global_system_variables.explicit_defaults_for_timestamp) thd->variables.explicit_defaults_for_timestamp= false; return; } /** Sensitive to Master-vs-Slave version difference features should be listed in the version non-descending order. */ static st_feature_version s_features[]= { // order is the same as in the enum { st_feature_version::WL6292_TIMESTAMP_EXPLICIT_DEFAULT, {5, 6, 6}, wl6292_upgrade_func, wl6292_downgrade_func }, { st_feature_version::_END_OF_LIST, {255, 255, 255}, NULL, NULL } }; /** The method lists rules of adaptation for the slave applier to specific master versions. It's executed right before a new master FD is set for slave appliers execution context. Comparison of the old and new version yields the adaptive actions direction. Current execution FD's version, V_0, is compared with the new being set up FD (the arg), let's call it V_1. In the case of downgrade features that are defined in [V_0, V_1-1] range (V_1 excluded) are "removed" by running the downgrade actions. In the upgrade case the featured defined in [V_0 + 1, V_1] range are "added" by running the upgrade actions. Notice, that due to relay log may have two FD events, one the slave local and the other from the Master. That can lead to extra adapt_to_master_version() calls and in case Slave and Master are of different versions the extra two calls should compensate each other. Also, at composing downgrade/upgrade actions keep in mind that at initialization Slave sets up FD of version 4.0 and then transits to the current server version. At transition all upgrading actions in the range of [4.0..current] are run. @param fdle a pointer to new Format Description event that is being set up for execution context. */ void Relay_log_info::adapt_to_master_version(Format_description_log_event *fdle) { THD *thd=info_thd; ulong master_version, current_version; int changed= !fdle || ! rli_description_event ? 0 : (master_version= fdle->get_version_product()) - (current_version= rli_description_event->get_version_product()); /* When the last version is not changed nothing to adapt for */ if (!changed) return; /* find item starting from and ending at for which adaptive actions run for downgrade or upgrade branches. (todo: convert into bsearch when number of features will grow significantly) */ bool downgrade= changed < 0; long i, i_first= st_feature_version::_END_OF_LIST, i_last= i_first; for (i= 0; i < st_feature_version::_END_OF_LIST; i++) { ulong ver_f= version_product(s_features[i].version_split); if ((downgrade ? master_version : current_version) < ver_f && i_first == st_feature_version::_END_OF_LIST) i_first= i; if ((downgrade ? current_version : master_version) < ver_f) { i_last= i; DBUG_ASSERT(i_last >= i_first); break; } } /* actions, executed in version non-descending st_feature_version order */ for (i= i_first; i < i_last; i++) { /* Run time check of the st_feature_version items ordering */ DBUG_ASSERT(!i || version_product(s_features[i - 1].version_split) <= version_product(s_features[i].version_split)); DBUG_ASSERT((downgrade ? master_version : current_version) < version_product(s_features[i].version_split) && (downgrade ? current_version : master_version >= version_product(s_features[i].version_split))); if (downgrade && s_features[i].downgrade) { s_features[i].downgrade(thd); } else if (s_features[i].upgrade) { s_features[i].upgrade(thd); } } } /** Flushes gtid info state after executing the current event. @param[in] force Forces the synchronization. @param[in] xid_event If we are executing XID event, the job of updating slave_gtid_info is delegated to storage engine. @return false Success true Failure */ int Relay_log_info::flush_gtid_infos(bool force, bool xid_event) { DBUG_ENTER("Relay_log_info::flush_gtid_infos"); bool error = false; if (gtid_mode > 0 && last_gtid[0] != 0) { for (uint i = 0; i < gtid_infos.elements; i++) { Gtid_info *gtid_info = *dynamic_element(&gtid_infos, i, Gtid_info**); DBUG_ASSERT(gtid_info); #ifndef DBUG_OFF DBUG_ASSERT(!gtid_info->skip_event(last_gtid)); #endif // Flush the gtid_info if this is the first time we // are updating the row in the slave_gtid_info table. if (strcmp(gtid_info->get_last_gtid_string(), "") == 0) force = true; gtid_info->set_last_gtid(last_gtid); if (xid_event && slave_gtid_info == SLAVE_GTID_INFO_OPTIMIZED) { // Delegate to storage engine. info_thd->append_slave_gtid_info(gtid_info->get_internal_id(), gtid_info->get_database_name(), gtid_info->get_last_gtid_string()); } else if (slave_gtid_info == SLAVE_GTID_INFO_ON && (error = gtid_info->flush_info(force))) break; } } /* Reset last_gtid to make sure we don't skip the next transaction which doesn't have GTID. */ last_gtid[0] = 0; reset_dynamic(&gtid_infos); DBUG_RETURN(error); }