mirror of
https://github.com/MariaDB/server.git
synced 2025-01-16 20:12:31 +01:00
0394cf2030
Preliminary commit for testing
778 lines
26 KiB
C++
778 lines
26 KiB
C++
/* Copyright (C) 2005 MySQL AB
|
|
|
|
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, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307 USA */
|
|
|
|
#ifndef LOG_H
|
|
#define LOG_H
|
|
|
|
class Relay_log_info;
|
|
|
|
class Format_description_log_event;
|
|
|
|
/*
|
|
Transaction Coordinator log - a base abstract class
|
|
for two different implementations
|
|
*/
|
|
class TC_LOG
|
|
{
|
|
public:
|
|
int using_heuristic_recover();
|
|
TC_LOG() {}
|
|
virtual ~TC_LOG() {}
|
|
|
|
virtual int open(const char *opt_name)=0;
|
|
virtual void close()=0;
|
|
virtual int log_and_order(THD *thd, my_xid xid, bool all,
|
|
bool need_prepare_ordered,
|
|
bool need_commit_ordered) = 0;
|
|
virtual void unlog(ulong cookie, my_xid xid)=0;
|
|
|
|
protected:
|
|
/*
|
|
These methods are meant to be invoked from log_and_order() implementations
|
|
to run any prepare_ordered() respectively commit_ordered() methods in
|
|
participating handlers.
|
|
|
|
They must be called using suitable thread syncronisation to ensure that
|
|
they are each called in the correct commit order among all
|
|
transactions. However, it is only necessary to call them if the
|
|
corresponding flag passed to log_and_order is set (it is safe, but not
|
|
required, to call them when the flag is false).
|
|
|
|
The caller must be holding LOCK_prepare_ordered respectively
|
|
LOCK_commit_ordered when calling these methods.
|
|
*/
|
|
void run_prepare_ordered(THD *thd, bool all);
|
|
void run_commit_ordered(THD *thd, bool all);
|
|
};
|
|
|
|
/*
|
|
Locks used to ensure serialised execution of TC_LOG::run_prepare_ordered()
|
|
and TC_LOG::run_commit_ordered(), or any other code that calls handler
|
|
prepare_ordered() or commit_ordered() methods.
|
|
*/
|
|
extern pthread_mutex_t LOCK_prepare_ordered;
|
|
extern pthread_mutex_t LOCK_commit_ordered;
|
|
|
|
extern void TC_init();
|
|
extern void TC_destroy();
|
|
|
|
/*
|
|
Base class for two TC implementations TC_LOG_unordered and
|
|
TC_LOG_group_commit that both use a queue of threads waiting for group
|
|
commit.
|
|
*/
|
|
class TC_LOG_queued: public TC_LOG
|
|
{
|
|
protected:
|
|
TC_LOG_queued();
|
|
~TC_LOG_queued();
|
|
|
|
/* Structure used to link list of THDs waiting for group commit. */
|
|
struct TC_group_commit_entry
|
|
{
|
|
struct TC_group_commit_entry *next;
|
|
THD *thd;
|
|
/* This is the `all' parameter for ha_commit_trans() etc. */
|
|
bool all;
|
|
/*
|
|
Flag set true when it is time for this thread to wake up after group
|
|
commit. Used with THD::LOCK_commit_ordered and THD::COND_commit_ordered.
|
|
*/
|
|
bool group_commit_ready;
|
|
/*
|
|
Set by TC_LOG_group_commit::group_log_xid(), to return per-thd error and
|
|
cookie.
|
|
*/
|
|
int xid_error;
|
|
};
|
|
|
|
TC_group_commit_entry * reverse_queue(TC_group_commit_entry *queue);
|
|
|
|
void group_commit_wait_for_wakeup(TC_group_commit_entry *entry);
|
|
void group_commit_wakeup_other(TC_group_commit_entry *other);
|
|
|
|
/*
|
|
This is a queue of threads waiting for being allowed to commit.
|
|
Access to the queue must be protected by LOCK_prepare_ordered.
|
|
*/
|
|
TC_group_commit_entry *group_commit_queue;
|
|
};
|
|
|
|
class TC_LOG_unordered: public TC_LOG_queued
|
|
{
|
|
public:
|
|
TC_LOG_unordered();
|
|
~TC_LOG_unordered();
|
|
|
|
int log_and_order(THD *thd, my_xid xid, bool all,
|
|
bool need_prepare_ordered, bool need_commit_ordered);
|
|
|
|
protected:
|
|
virtual int log_xid(THD *thd, my_xid xid)=0;
|
|
|
|
private:
|
|
/*
|
|
This flag and condition is used to reserve the queue while threads in it
|
|
each run the commit_ordered() methods one after the other. Only once the
|
|
last commit_ordered() in the queue is done can we start on a new queue
|
|
run.
|
|
|
|
Since we start this process in the first thread in the queue and finish in
|
|
the last (and possibly different) thread, we need a condition variable for
|
|
this (we cannot unlock a mutex in a different thread than the one who
|
|
locked it).
|
|
|
|
The condition is used together with the LOCK_prepare_ordered mutex.
|
|
*/
|
|
my_bool group_commit_queue_busy;
|
|
pthread_cond_t COND_queue_busy;
|
|
};
|
|
|
|
class TC_LOG_group_commit: public TC_LOG_queued
|
|
{
|
|
public:
|
|
TC_LOG_group_commit();
|
|
~TC_LOG_group_commit();
|
|
|
|
int log_and_order(THD *thd, my_xid xid, bool all,
|
|
bool need_prepare_ordered, bool need_commit_ordered);
|
|
|
|
protected:
|
|
/* Total number of committed transactions. */
|
|
ulonglong num_commits;
|
|
/* Number of group commits done. */
|
|
ulonglong num_group_commits;
|
|
|
|
/*
|
|
When using this class, this method is used instead of log_xid() to do
|
|
logging of a group of transactions all at once.
|
|
|
|
The transactions will be linked through THD::next_commit_ordered.
|
|
|
|
Additionally, when this method is used instead of log_xid(), the order in
|
|
which handler->prepare_ordered() and handler->commit_ordered() are called
|
|
is guaranteed to be the same as the order of calls and THD list elements
|
|
for group_log_xid().
|
|
|
|
This can be used to efficiently implement group commit that at the same
|
|
time preserves the order of commits among handlers and TC (eg. to get same
|
|
commit order in InnoDB and binary log).
|
|
|
|
For TCs that do not need this, it can be preferable to use plain log_xid()
|
|
with class TC_LOG_unordered instead, as it allows threads to run log_xid()
|
|
in parallel with each other. In contrast, group_log_xid() runs under a
|
|
global mutex, so it is guaranteed that only once call into it will be
|
|
active at once.
|
|
|
|
Since this call handles multiple threads/THDs at once, my_error() (and
|
|
other code that relies on thread local storage) cannot be used in this
|
|
method. Instead, the implementation must record any error and report it as
|
|
the return value from xid_log_after(), which will be invoked individually
|
|
for each thread.
|
|
|
|
In the success case, this method must set thd->xid_cookie for each thread
|
|
to the cookie that is normally returned from log_xid() (which must be
|
|
non-zero in the non-error case).
|
|
*/
|
|
virtual void group_log_xid(TC_group_commit_entry *first) = 0;
|
|
/*
|
|
Called for each transaction (in corrent thread context) after
|
|
group_log_xid() has finished, but with no guarantee on ordering among
|
|
threads.
|
|
Can be used to do error reporting etc. */
|
|
virtual int xid_log_after(TC_group_commit_entry *entry) = 0;
|
|
|
|
private:
|
|
/* Mutex used to serialise calls to group_log_xid(). */
|
|
pthread_mutex_t LOCK_group_commit;
|
|
};
|
|
|
|
class TC_LOG_DUMMY: public TC_LOG_unordered // use it to disable the logging
|
|
{
|
|
public:
|
|
TC_LOG_DUMMY() {}
|
|
int open(const char *opt_name) { return 0; }
|
|
void close() { }
|
|
int log_xid(THD *thd, my_xid xid) { return 1; }
|
|
void unlog(ulong cookie, my_xid xid) { }
|
|
};
|
|
|
|
#ifdef HAVE_MMAP
|
|
class TC_LOG_MMAP: public TC_LOG_unordered
|
|
{
|
|
public: // only to keep Sun Forte on sol9x86 happy
|
|
typedef enum {
|
|
POOL, // page is in pool
|
|
ERROR, // last sync failed
|
|
DIRTY // new xids added since last sync
|
|
} PAGE_STATE;
|
|
|
|
private:
|
|
typedef struct st_page {
|
|
struct st_page *next; // page a linked in a fifo queue
|
|
my_xid *start, *end; // usable area of a page
|
|
my_xid *ptr; // next xid will be written here
|
|
int size, free; // max and current number of free xid slots on the page
|
|
int waiters; // number of waiters on condition
|
|
PAGE_STATE state; // see above
|
|
pthread_mutex_t lock; // to access page data or control structure
|
|
pthread_cond_t cond; // to wait for a sync
|
|
} PAGE;
|
|
|
|
char logname[FN_REFLEN];
|
|
File fd;
|
|
my_off_t file_length;
|
|
uint npages, inited;
|
|
uchar *data;
|
|
struct st_page *pages, *syncing, *active, *pool, *pool_last;
|
|
/*
|
|
note that, e.g. LOCK_active is only used to protect
|
|
'active' pointer, to protect the content of the active page
|
|
one has to use active->lock.
|
|
Same for LOCK_pool and LOCK_sync
|
|
*/
|
|
pthread_mutex_t LOCK_active, LOCK_pool, LOCK_sync;
|
|
pthread_cond_t COND_pool, COND_active;
|
|
|
|
public:
|
|
TC_LOG_MMAP(): inited(0) {}
|
|
int open(const char *opt_name);
|
|
void close();
|
|
int log_xid(THD *thd, my_xid xid);
|
|
void unlog(ulong cookie, my_xid xid);
|
|
int recover();
|
|
|
|
private:
|
|
void get_active_from_pool();
|
|
int sync();
|
|
int overflow();
|
|
};
|
|
#else
|
|
#define TC_LOG_MMAP TC_LOG_DUMMY
|
|
#endif
|
|
|
|
extern TC_LOG *tc_log;
|
|
extern TC_LOG_MMAP tc_log_mmap;
|
|
extern TC_LOG_DUMMY tc_log_dummy;
|
|
|
|
/* log info errors */
|
|
#define LOG_INFO_EOF -1
|
|
#define LOG_INFO_IO -2
|
|
#define LOG_INFO_INVALID -3
|
|
#define LOG_INFO_SEEK -4
|
|
#define LOG_INFO_MEM -6
|
|
#define LOG_INFO_FATAL -7
|
|
#define LOG_INFO_IN_USE -8
|
|
#define LOG_INFO_EMFILE -9
|
|
|
|
|
|
/* bitmap to SQL_LOG::close() */
|
|
#define LOG_CLOSE_INDEX 1
|
|
#define LOG_CLOSE_TO_BE_OPENED 2
|
|
#define LOG_CLOSE_STOP_EVENT 4
|
|
|
|
class Relay_log_info;
|
|
|
|
typedef struct st_log_info
|
|
{
|
|
char log_file_name[FN_REFLEN];
|
|
my_off_t index_file_offset, index_file_start_offset;
|
|
my_off_t pos;
|
|
bool fatal; // if the purge happens to give us a negative offset
|
|
pthread_mutex_t lock;
|
|
st_log_info()
|
|
: index_file_offset(0), index_file_start_offset(0),
|
|
pos(0), fatal(0)
|
|
{
|
|
log_file_name[0] = '\0';
|
|
pthread_mutex_init(&lock, MY_MUTEX_INIT_FAST);
|
|
}
|
|
~st_log_info() { pthread_mutex_destroy(&lock);}
|
|
} LOG_INFO;
|
|
|
|
/*
|
|
Currently we have only 3 kinds of logging functions: old-fashioned
|
|
logs, stdout and csv logging routines.
|
|
*/
|
|
#define MAX_LOG_HANDLERS_NUM 3
|
|
|
|
/* log event handler flags */
|
|
#define LOG_NONE 1
|
|
#define LOG_FILE 2
|
|
#define LOG_TABLE 4
|
|
|
|
class Log_event;
|
|
class Rows_log_event;
|
|
|
|
enum enum_log_type { LOG_UNKNOWN, LOG_NORMAL, LOG_BIN };
|
|
enum enum_log_state { LOG_OPENED, LOG_CLOSED, LOG_TO_BE_OPENED };
|
|
|
|
/*
|
|
TODO use mmap instead of IO_CACHE for binlog
|
|
(mmap+fsync is two times faster than write+fsync)
|
|
*/
|
|
|
|
class MYSQL_LOG
|
|
{
|
|
public:
|
|
MYSQL_LOG();
|
|
void init_pthread_objects();
|
|
void cleanup();
|
|
bool open(const char *log_name,
|
|
enum_log_type log_type,
|
|
const char *new_name,
|
|
enum cache_type io_cache_type_arg);
|
|
bool init_and_set_log_file_name(const char *log_name,
|
|
const char *new_name,
|
|
enum_log_type log_type_arg,
|
|
enum cache_type io_cache_type_arg);
|
|
void init(enum_log_type log_type_arg,
|
|
enum cache_type io_cache_type_arg);
|
|
void close(uint exiting);
|
|
inline bool is_open() { return log_state != LOG_CLOSED; }
|
|
const char *generate_name(const char *log_name, const char *suffix,
|
|
bool strip_ext, char *buff);
|
|
int generate_new_name(char *new_name, const char *log_name);
|
|
protected:
|
|
/* LOCK_log is inited by init_pthread_objects() */
|
|
pthread_mutex_t LOCK_log;
|
|
char *name;
|
|
char log_file_name[FN_REFLEN];
|
|
char time_buff[20], db[NAME_LEN + 1];
|
|
bool write_error, inited;
|
|
IO_CACHE log_file;
|
|
enum_log_type log_type;
|
|
volatile enum_log_state log_state;
|
|
enum cache_type io_cache_type;
|
|
friend class Log_event;
|
|
};
|
|
|
|
class MYSQL_QUERY_LOG: public MYSQL_LOG
|
|
{
|
|
public:
|
|
MYSQL_QUERY_LOG() : last_time(0) {}
|
|
void reopen_file();
|
|
bool write(time_t event_time, const char *user_host,
|
|
uint user_host_len, int thread_id,
|
|
const char *command_type, uint command_type_len,
|
|
const char *sql_text, uint sql_text_len);
|
|
bool write(THD *thd, time_t current_time, time_t query_start_arg,
|
|
const char *user_host, uint user_host_len,
|
|
ulonglong query_utime, ulonglong lock_utime, bool is_command,
|
|
const char *sql_text, uint sql_text_len);
|
|
bool open_slow_log(const char *log_name)
|
|
{
|
|
char buf[FN_REFLEN];
|
|
return open(generate_name(log_name, "-slow.log", 0, buf), LOG_NORMAL, 0,
|
|
WRITE_CACHE);
|
|
}
|
|
bool open_query_log(const char *log_name)
|
|
{
|
|
char buf[FN_REFLEN];
|
|
return open(generate_name(log_name, ".log", 0, buf), LOG_NORMAL, 0,
|
|
WRITE_CACHE);
|
|
}
|
|
|
|
private:
|
|
time_t last_time;
|
|
};
|
|
|
|
class binlog_trx_data;
|
|
class MYSQL_BIN_LOG: public TC_LOG_group_commit, private MYSQL_LOG
|
|
{
|
|
private:
|
|
/* LOCK_log and LOCK_index are inited by init_pthread_objects() */
|
|
pthread_mutex_t LOCK_index;
|
|
pthread_mutex_t LOCK_prep_xids;
|
|
/*
|
|
Mutex to protect the queue of transactions waiting to participate in group
|
|
commit. (Only used on platforms without native atomic operations).
|
|
*/
|
|
pthread_mutex_t LOCK_queue;
|
|
|
|
pthread_cond_t COND_prep_xids;
|
|
pthread_cond_t update_cond;
|
|
ulonglong bytes_written;
|
|
IO_CACHE index_file;
|
|
char index_file_name[FN_REFLEN];
|
|
/*
|
|
purge_file is a temp file used in purge_logs so that the index file
|
|
can be updated before deleting files from disk, yielding better crash
|
|
recovery. It is created on demand the first time purge_logs is called
|
|
and then reused for subsequent calls. It is cleaned up in cleanup().
|
|
*/
|
|
IO_CACHE purge_index_file;
|
|
char purge_index_file_name[FN_REFLEN];
|
|
/*
|
|
The max size before rotation (usable only if log_type == LOG_BIN: binary
|
|
logs and relay logs).
|
|
For a binlog, max_size should be max_binlog_size.
|
|
For a relay log, it should be max_relay_log_size if this is non-zero,
|
|
max_binlog_size otherwise.
|
|
max_size is set in init(), and dynamically changed (when one does SET
|
|
GLOBAL MAX_BINLOG_SIZE|MAX_RELAY_LOG_SIZE) by fix_max_binlog_size and
|
|
fix_max_relay_log_size).
|
|
*/
|
|
ulong max_size;
|
|
long prepared_xids; /* for tc log - number of xids to remember */
|
|
// current file sequence number for load data infile binary logging
|
|
uint file_id;
|
|
uint open_count; // For replication
|
|
int readers_count;
|
|
bool need_start_event;
|
|
/*
|
|
no_auto_events means we don't want any of these automatic events :
|
|
Start/Rotate/Stop. That is, in 4.x when we rotate a relay log, we don't
|
|
want a Rotate_log event to be written to the relay log. When we start a
|
|
relay log etc. So in 4.x this is 1 for relay logs, 0 for binlogs.
|
|
In 5.0 it's 0 for relay logs too!
|
|
*/
|
|
bool no_auto_events;
|
|
/* Queue of transactions queued up to participate in group commit. */
|
|
binlog_trx_data *group_commit_queue;
|
|
|
|
int write_to_file(IO_CACHE *cache);
|
|
/*
|
|
This is used to start writing to a new log file. The difference from
|
|
new_file() is locking. new_file_without_locking() does not acquire
|
|
LOCK_log.
|
|
*/
|
|
void new_file_without_locking();
|
|
void new_file_impl(bool need_lock);
|
|
int write_transaction(binlog_trx_data *trx_data);
|
|
bool write_transaction_to_binlog_events(binlog_trx_data *trx_data);
|
|
void trx_group_commit_participant(binlog_trx_data *trx_data);
|
|
void trx_group_commit_leader(TC_group_commit_entry *first);
|
|
binlog_trx_data *atomic_enqueue_trx(binlog_trx_data *trx_data);
|
|
binlog_trx_data *atomic_grab_trx_queue();
|
|
void mark_xid_done();
|
|
void mark_xids_active(uint xid_count);
|
|
|
|
public:
|
|
MYSQL_LOG::generate_name;
|
|
MYSQL_LOG::is_open;
|
|
|
|
/* This is relay log */
|
|
bool is_relay_log;
|
|
|
|
/*
|
|
These describe the log's format. This is used only for relay logs.
|
|
_for_exec is used by the SQL thread, _for_queue by the I/O thread. It's
|
|
necessary to have 2 distinct objects, because the I/O thread may be reading
|
|
events in a different format from what the SQL thread is reading (consider
|
|
the case of a master which has been upgraded from 5.0 to 5.1 without doing
|
|
RESET MASTER, or from 4.x to 5.0).
|
|
*/
|
|
Format_description_log_event *description_event_for_exec,
|
|
*description_event_for_queue;
|
|
|
|
MYSQL_BIN_LOG();
|
|
/*
|
|
note that there's no destructor ~MYSQL_BIN_LOG() !
|
|
The reason is that we don't want it to be automatically called
|
|
on exit() - but only during the correct shutdown process
|
|
*/
|
|
|
|
int open(const char *opt_name);
|
|
void close();
|
|
void group_log_xid(TC_group_commit_entry *first);
|
|
int xid_log_after(TC_group_commit_entry *entry);
|
|
void unlog(ulong cookie, my_xid xid);
|
|
int recover(IO_CACHE *log, Format_description_log_event *fdle);
|
|
#if !defined(MYSQL_CLIENT)
|
|
int flush_and_set_pending_rows_event(THD *thd, Rows_log_event* event);
|
|
int remove_pending_rows_event(THD *thd);
|
|
|
|
#endif /* !defined(MYSQL_CLIENT) */
|
|
void reset_bytes_written()
|
|
{
|
|
bytes_written = 0;
|
|
}
|
|
void harvest_bytes_written(ulonglong* counter)
|
|
{
|
|
#ifndef DBUG_OFF
|
|
char buf1[22],buf2[22];
|
|
#endif
|
|
DBUG_ENTER("harvest_bytes_written");
|
|
(*counter)+=bytes_written;
|
|
DBUG_PRINT("info",("counter: %s bytes_written: %s", llstr(*counter,buf1),
|
|
llstr(bytes_written,buf2)));
|
|
bytes_written=0;
|
|
DBUG_VOID_RETURN;
|
|
}
|
|
void set_max_size(ulong max_size_arg);
|
|
void signal_update();
|
|
void wait_for_update(THD* thd, bool master_or_slave);
|
|
void set_need_start_event() { need_start_event = 1; }
|
|
void init(bool no_auto_events_arg, ulong max_size);
|
|
void init_pthread_objects();
|
|
void cleanup();
|
|
bool open(const char *log_name,
|
|
enum_log_type log_type,
|
|
const char *new_name,
|
|
enum cache_type io_cache_type_arg,
|
|
bool no_auto_events_arg, ulong max_size,
|
|
bool null_created,
|
|
bool need_mutex);
|
|
bool open_index_file(const char *index_file_name_arg,
|
|
const char *log_name, bool need_mutex);
|
|
/* Use this to start writing a new log file */
|
|
void new_file();
|
|
|
|
bool write(Log_event* event_info); // binary log write
|
|
bool write_transaction_to_binlog(THD *thd, binlog_trx_data *trx_data,
|
|
Log_event *end_ev);
|
|
bool trx_group_commit_finish(binlog_trx_data *trx_data);
|
|
bool write_incident(THD *thd);
|
|
|
|
int write_cache(IO_CACHE *cache);
|
|
void set_write_error(THD *thd);
|
|
bool check_write_error(THD *thd);
|
|
|
|
void start_union_events(THD *thd, query_id_t query_id_param);
|
|
void stop_union_events(THD *thd);
|
|
bool is_query_in_union(THD *thd, query_id_t query_id_param);
|
|
|
|
/*
|
|
v stands for vector
|
|
invoked as appendv(buf1,len1,buf2,len2,...,bufn,lenn,0)
|
|
*/
|
|
bool appendv(const char* buf,uint len,...);
|
|
bool append(Log_event* ev);
|
|
|
|
void make_log_name(char* buf, const char* log_ident);
|
|
bool is_active(const char* log_file_name);
|
|
int update_log_index(LOG_INFO* linfo, bool need_update_threads);
|
|
void rotate_and_purge(uint flags);
|
|
bool flush_and_sync();
|
|
int purge_logs(const char *to_log, bool included,
|
|
bool need_mutex, bool need_update_threads,
|
|
ulonglong *decrease_log_space);
|
|
int purge_logs_before_date(time_t purge_time);
|
|
int purge_first_log(Relay_log_info* rli, bool included);
|
|
int set_purge_index_file_name(const char *base_file_name);
|
|
int open_purge_index_file(bool destroy);
|
|
bool is_inited_purge_index_file();
|
|
int close_purge_index_file();
|
|
int clean_purge_index_file();
|
|
int sync_purge_index_file();
|
|
int register_purge_index_entry(const char* entry);
|
|
int register_create_index_entry(const char* entry);
|
|
int purge_index_entry(THD *thd, ulonglong *decrease_log_space,
|
|
bool need_mutex);
|
|
bool reset_logs(THD* thd);
|
|
void close(uint exiting);
|
|
|
|
// iterating through the log index file
|
|
int find_log_pos(LOG_INFO* linfo, const char* log_name,
|
|
bool need_mutex);
|
|
int find_next_log(LOG_INFO* linfo, bool need_mutex);
|
|
int get_current_log(LOG_INFO* linfo);
|
|
int raw_get_current_log(LOG_INFO* linfo);
|
|
uint next_file_id();
|
|
inline char* get_index_fname() { return index_file_name;}
|
|
inline char* get_log_fname() { return log_file_name; }
|
|
inline char* get_name() { return name; }
|
|
inline pthread_mutex_t* get_log_lock() { return &LOCK_log; }
|
|
inline IO_CACHE* get_log_file() { return &log_file; }
|
|
|
|
inline void lock_index() { pthread_mutex_lock(&LOCK_index);}
|
|
inline void unlock_index() { pthread_mutex_unlock(&LOCK_index);}
|
|
inline IO_CACHE *get_index_file() { return &index_file;}
|
|
inline uint32 get_open_count() { return open_count; }
|
|
void set_status_variables();
|
|
};
|
|
|
|
class Log_event_handler
|
|
{
|
|
public:
|
|
Log_event_handler() {}
|
|
virtual bool init()= 0;
|
|
virtual void cleanup()= 0;
|
|
|
|
virtual bool log_slow(THD *thd, time_t current_time,
|
|
time_t query_start_arg, const char *user_host,
|
|
uint user_host_len, ulonglong query_utime,
|
|
ulonglong lock_utime, bool is_command,
|
|
const char *sql_text, uint sql_text_len)= 0;
|
|
virtual bool log_error(enum loglevel level, const char *format,
|
|
va_list args)= 0;
|
|
virtual bool log_general(THD *thd, time_t event_time, const char *user_host,
|
|
uint user_host_len, int thread_id,
|
|
const char *command_type, uint command_type_len,
|
|
const char *sql_text, uint sql_text_len,
|
|
CHARSET_INFO *client_cs)= 0;
|
|
virtual ~Log_event_handler() {}
|
|
};
|
|
|
|
|
|
int check_if_log_table(uint db_len, const char *db, uint table_name_len,
|
|
const char *table_name, uint check_if_opened);
|
|
|
|
class Log_to_csv_event_handler: public Log_event_handler
|
|
{
|
|
friend class LOGGER;
|
|
|
|
public:
|
|
Log_to_csv_event_handler();
|
|
~Log_to_csv_event_handler();
|
|
virtual bool init();
|
|
virtual void cleanup();
|
|
|
|
virtual bool log_slow(THD *thd, time_t current_time,
|
|
time_t query_start_arg, const char *user_host,
|
|
uint user_host_len, ulonglong query_utime,
|
|
ulonglong lock_utime, bool is_command,
|
|
const char *sql_text, uint sql_text_len);
|
|
virtual bool log_error(enum loglevel level, const char *format,
|
|
va_list args);
|
|
virtual bool log_general(THD *thd, time_t event_time, const char *user_host,
|
|
uint user_host_len, int thread_id,
|
|
const char *command_type, uint command_type_len,
|
|
const char *sql_text, uint sql_text_len,
|
|
CHARSET_INFO *client_cs);
|
|
|
|
int activate_log(THD *thd, uint log_type);
|
|
};
|
|
|
|
|
|
/* type of the log table */
|
|
#define QUERY_LOG_SLOW 1
|
|
#define QUERY_LOG_GENERAL 2
|
|
|
|
class Log_to_file_event_handler: public Log_event_handler
|
|
{
|
|
MYSQL_QUERY_LOG mysql_log;
|
|
MYSQL_QUERY_LOG mysql_slow_log;
|
|
bool is_initialized;
|
|
public:
|
|
Log_to_file_event_handler(): is_initialized(FALSE)
|
|
{}
|
|
virtual bool init();
|
|
virtual void cleanup();
|
|
|
|
virtual bool log_slow(THD *thd, time_t current_time,
|
|
time_t query_start_arg, const char *user_host,
|
|
uint user_host_len, ulonglong query_utime,
|
|
ulonglong lock_utime, bool is_command,
|
|
const char *sql_text, uint sql_text_len);
|
|
virtual bool log_error(enum loglevel level, const char *format,
|
|
va_list args);
|
|
virtual bool log_general(THD *thd, time_t event_time, const char *user_host,
|
|
uint user_host_len, int thread_id,
|
|
const char *command_type, uint command_type_len,
|
|
const char *sql_text, uint sql_text_len,
|
|
CHARSET_INFO *client_cs);
|
|
void flush();
|
|
void init_pthread_objects();
|
|
MYSQL_QUERY_LOG *get_mysql_slow_log() { return &mysql_slow_log; }
|
|
MYSQL_QUERY_LOG *get_mysql_log() { return &mysql_log; }
|
|
};
|
|
|
|
|
|
/* Class which manages slow, general and error log event handlers */
|
|
class LOGGER
|
|
{
|
|
rw_lock_t LOCK_logger;
|
|
/* flag to check whether logger mutex is initialized */
|
|
uint inited;
|
|
|
|
/* available log handlers */
|
|
Log_to_csv_event_handler *table_log_handler;
|
|
Log_to_file_event_handler *file_log_handler;
|
|
|
|
/* NULL-terminated arrays of log handlers */
|
|
Log_event_handler *error_log_handler_list[MAX_LOG_HANDLERS_NUM + 1];
|
|
Log_event_handler *slow_log_handler_list[MAX_LOG_HANDLERS_NUM + 1];
|
|
Log_event_handler *general_log_handler_list[MAX_LOG_HANDLERS_NUM + 1];
|
|
|
|
public:
|
|
|
|
bool is_log_tables_initialized;
|
|
|
|
LOGGER() : inited(0), table_log_handler(NULL),
|
|
file_log_handler(NULL), is_log_tables_initialized(FALSE)
|
|
{}
|
|
void lock_shared() { rw_rdlock(&LOCK_logger); }
|
|
void lock_exclusive() { rw_wrlock(&LOCK_logger); }
|
|
void unlock() { rw_unlock(&LOCK_logger); }
|
|
bool is_log_table_enabled(uint log_table_type);
|
|
bool log_command(THD *thd, enum enum_server_command command);
|
|
|
|
/*
|
|
We want to initialize all log mutexes as soon as possible,
|
|
but we cannot do it in constructor, as safe_mutex relies on
|
|
initialization, performed by MY_INIT(). This why this is done in
|
|
this function.
|
|
*/
|
|
void init_base();
|
|
void init_log_tables();
|
|
bool flush_logs(THD *thd);
|
|
/* Perform basic logger cleanup. this will leave e.g. error log open. */
|
|
void cleanup_base();
|
|
/* Free memory. Nothing could be logged after this function is called */
|
|
void cleanup_end();
|
|
bool error_log_print(enum loglevel level, const char *format,
|
|
va_list args);
|
|
bool slow_log_print(THD *thd, const char *query, uint query_length,
|
|
ulonglong current_utime);
|
|
bool general_log_print(THD *thd,enum enum_server_command command,
|
|
const char *format, va_list args);
|
|
bool general_log_write(THD *thd, enum enum_server_command command,
|
|
const char *query, uint query_length);
|
|
|
|
/* we use this function to setup all enabled log event handlers */
|
|
int set_handlers(uint error_log_printer,
|
|
uint slow_log_printer,
|
|
uint general_log_printer);
|
|
void init_error_log(uint error_log_printer);
|
|
void init_slow_log(uint slow_log_printer);
|
|
void init_general_log(uint general_log_printer);
|
|
void deactivate_log_handler(THD* thd, uint log_type);
|
|
bool activate_log_handler(THD* thd, uint log_type);
|
|
MYSQL_QUERY_LOG *get_slow_log_file_handler()
|
|
{
|
|
if (file_log_handler)
|
|
return file_log_handler->get_mysql_slow_log();
|
|
return NULL;
|
|
}
|
|
MYSQL_QUERY_LOG *get_log_file_handler()
|
|
{
|
|
if (file_log_handler)
|
|
return file_log_handler->get_mysql_log();
|
|
return NULL;
|
|
}
|
|
};
|
|
|
|
enum enum_binlog_format {
|
|
/*
|
|
statement-based except for cases where only row-based can work (UUID()
|
|
etc):
|
|
*/
|
|
BINLOG_FORMAT_MIXED= 0,
|
|
BINLOG_FORMAT_STMT= 1, // statement-based
|
|
BINLOG_FORMAT_ROW= 2, // row_based
|
|
/*
|
|
This value is last, after the end of binlog_format_typelib: it has no
|
|
corresponding cell in this typelib. We use this value to be able to know if
|
|
the user has explicitely specified a binlog format at startup or not.
|
|
*/
|
|
BINLOG_FORMAT_UNSPEC= 3
|
|
};
|
|
extern TYPELIB binlog_format_typelib;
|
|
|
|
int query_error_code(THD *thd, bool not_killed);
|
|
|
|
#endif /* LOG_H */
|