2016-06-16 09:15:56 +00:00
|
|
|
package replication
|
|
|
|
|
|
|
|
import (
|
2019-01-01 08:57:46 +00:00
|
|
|
"context"
|
2017-02-12 11:13:54 +00:00
|
|
|
"crypto/tls"
|
2016-06-16 09:15:56 +00:00
|
|
|
"encoding/binary"
|
|
|
|
"fmt"
|
2019-01-01 08:57:46 +00:00
|
|
|
"net"
|
2016-06-16 09:15:56 +00:00
|
|
|
"os"
|
2019-01-01 08:57:46 +00:00
|
|
|
"strings"
|
2016-06-16 09:15:56 +00:00
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/juju/errors"
|
2019-01-01 08:57:46 +00:00
|
|
|
"github.com/satori/go.uuid"
|
|
|
|
"github.com/siddontang/go-log/log"
|
2016-06-16 09:15:56 +00:00
|
|
|
"github.com/siddontang/go-mysql/client"
|
|
|
|
. "github.com/siddontang/go-mysql/mysql"
|
|
|
|
)
|
|
|
|
|
|
|
|
var (
|
2017-02-12 11:13:54 +00:00
|
|
|
errSyncRunning = errors.New("Sync is running, must Close first")
|
2016-06-16 09:15:56 +00:00
|
|
|
)
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// BinlogSyncerConfig is the configuration for BinlogSyncer.
|
|
|
|
type BinlogSyncerConfig struct {
|
|
|
|
// ServerID is the unique ID in cluster.
|
|
|
|
ServerID uint32
|
|
|
|
// Flavor is "mysql" or "mariadb", if not set, use "mysql" default.
|
|
|
|
Flavor string
|
|
|
|
|
|
|
|
// Host is for MySQL server host.
|
|
|
|
Host string
|
|
|
|
// Port is for MySQL server port.
|
|
|
|
Port uint16
|
|
|
|
// User is for MySQL user.
|
|
|
|
User string
|
|
|
|
// Password is for MySQL password.
|
|
|
|
Password string
|
|
|
|
|
|
|
|
// Localhost is local hostname if register salve.
|
|
|
|
// If not set, use os.Hostname() instead.
|
|
|
|
Localhost string
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
// Charset is for MySQL client character set
|
|
|
|
Charset string
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// SemiSyncEnabled enables semi-sync or not.
|
|
|
|
SemiSyncEnabled bool
|
|
|
|
|
2018-04-11 06:11:27 +00:00
|
|
|
// RawModeEnabled is for not parsing binlog event.
|
|
|
|
RawModeEnabled bool
|
2017-02-12 11:13:54 +00:00
|
|
|
|
|
|
|
// If not nil, use the provided tls.Config to connect to the database using TLS/SSL.
|
|
|
|
TLSConfig *tls.Config
|
2019-01-01 08:57:46 +00:00
|
|
|
|
|
|
|
// Use replication.Time structure for timestamp and datetime.
|
|
|
|
// We will use Local location for timestamp and UTC location for datatime.
|
|
|
|
ParseTime bool
|
|
|
|
|
|
|
|
// If ParseTime is false, convert TIMESTAMP into this specified timezone. If
|
|
|
|
// ParseTime is true, this option will have no effect and TIMESTAMP data will
|
|
|
|
// be parsed into the local timezone and a full time.Time struct will be
|
|
|
|
// returned.
|
|
|
|
//
|
|
|
|
// Note that MySQL TIMESTAMP columns are offset from the machine local
|
|
|
|
// timezone while DATETIME columns are offset from UTC. This is consistent
|
|
|
|
// with documented MySQL behaviour as it return TIMESTAMP in local timezone
|
|
|
|
// and DATETIME in UTC.
|
|
|
|
//
|
|
|
|
// Setting this to UTC effectively equalizes the TIMESTAMP and DATETIME time
|
|
|
|
// strings obtained from MySQL.
|
|
|
|
TimestampStringLocation *time.Location
|
|
|
|
|
|
|
|
// Use decimal.Decimal structure for decimals.
|
|
|
|
UseDecimal bool
|
|
|
|
|
|
|
|
// RecvBufferSize sets the size in bytes of the operating system's receive buffer associated with the connection.
|
|
|
|
RecvBufferSize int
|
|
|
|
|
|
|
|
// master heartbeat period
|
|
|
|
HeartbeatPeriod time.Duration
|
|
|
|
|
|
|
|
// read timeout
|
|
|
|
ReadTimeout time.Duration
|
|
|
|
|
|
|
|
// maximum number of attempts to re-establish a broken connection
|
|
|
|
MaxReconnectAttempts int
|
|
|
|
|
|
|
|
// Only works when MySQL/MariaDB variable binlog_checksum=CRC32.
|
|
|
|
// For MySQL, binlog_checksum was introduced since 5.6.2, but CRC32 was set as default value since 5.6.6 .
|
|
|
|
// https://dev.mysql.com/doc/refman/5.6/en/replication-options-binary-log.html#option_mysqld_binlog-checksum
|
|
|
|
// For MariaDB, binlog_checksum was introduced since MariaDB 5.3, but CRC32 was set as default value since MariaDB 10.2.1 .
|
|
|
|
// https://mariadb.com/kb/en/library/replication-and-binary-log-server-system-variables/#binlog_checksum
|
|
|
|
VerifyChecksum bool
|
2017-02-12 11:13:54 +00:00
|
|
|
}
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// BinlogSyncer syncs binlog event from server.
|
|
|
|
type BinlogSyncer struct {
|
|
|
|
m sync.RWMutex
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2018-01-11 12:51:14 +00:00
|
|
|
cfg BinlogSyncerConfig
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
c *client.Conn
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
wg sync.WaitGroup
|
|
|
|
|
|
|
|
parser *BinlogParser
|
|
|
|
|
|
|
|
nextPos Position
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
gset GTIDSet
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
running bool
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
ctx context.Context
|
|
|
|
cancel context.CancelFunc
|
2019-01-01 08:57:46 +00:00
|
|
|
|
|
|
|
lastConnectionID uint32
|
|
|
|
|
|
|
|
retryCount int
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// NewBinlogSyncer creates the BinlogSyncer with cfg.
|
2018-01-11 12:51:14 +00:00
|
|
|
func NewBinlogSyncer(cfg BinlogSyncerConfig) *BinlogSyncer {
|
2019-01-01 08:57:46 +00:00
|
|
|
if cfg.ServerID == 0 {
|
|
|
|
log.Fatal("can't use 0 as the server ID")
|
|
|
|
}
|
2018-01-11 12:51:14 +00:00
|
|
|
|
|
|
|
// Clear the Password to avoid outputing it in log.
|
|
|
|
pass := cfg.Password
|
|
|
|
cfg.Password = ""
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Infof("create BinlogSyncer with config %v", cfg)
|
2018-01-11 12:51:14 +00:00
|
|
|
cfg.Password = pass
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
b := new(BinlogSyncer)
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
b.cfg = cfg
|
2016-06-16 09:15:56 +00:00
|
|
|
b.parser = NewBinlogParser()
|
2018-04-11 06:11:27 +00:00
|
|
|
b.parser.SetRawMode(b.cfg.RawModeEnabled)
|
2019-01-01 08:57:46 +00:00
|
|
|
b.parser.SetParseTime(b.cfg.ParseTime)
|
|
|
|
b.parser.SetTimestampStringLocation(b.cfg.TimestampStringLocation)
|
|
|
|
b.parser.SetUseDecimal(b.cfg.UseDecimal)
|
|
|
|
b.parser.SetVerifyChecksum(b.cfg.VerifyChecksum)
|
2016-06-16 09:15:56 +00:00
|
|
|
b.running = false
|
2017-02-12 11:13:54 +00:00
|
|
|
b.ctx, b.cancel = context.WithCancel(context.Background())
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
return b
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// Close closes the BinlogSyncer.
|
2016-06-16 09:15:56 +00:00
|
|
|
func (b *BinlogSyncer) Close() {
|
|
|
|
b.m.Lock()
|
|
|
|
defer b.m.Unlock()
|
|
|
|
|
|
|
|
b.close()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) close() {
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.isClosed() {
|
|
|
|
return
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Info("syncer is closing...")
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
b.running = false
|
|
|
|
b.cancel()
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
if b.c != nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
b.c.SetReadDeadline(time.Now().Add(100 * time.Millisecond))
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
b.wg.Wait()
|
2016-06-16 09:15:56 +00:00
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.c != nil {
|
|
|
|
b.c.Close()
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Info("syncer is closed")
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
func (b *BinlogSyncer) isClosed() bool {
|
|
|
|
select {
|
|
|
|
case <-b.ctx.Done():
|
|
|
|
return true
|
|
|
|
default:
|
|
|
|
return false
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
func (b *BinlogSyncer) registerSlave() error {
|
|
|
|
if b.c != nil {
|
|
|
|
b.c.Close()
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
addr := ""
|
|
|
|
if strings.Contains(b.cfg.Host, "/") {
|
|
|
|
addr = b.cfg.Host
|
|
|
|
} else {
|
|
|
|
addr = fmt.Sprintf("%s:%d", b.cfg.Host, b.cfg.Port)
|
|
|
|
}
|
|
|
|
|
|
|
|
log.Infof("register slave for master server %s", addr)
|
2016-06-16 09:15:56 +00:00
|
|
|
var err error
|
2019-01-01 08:57:46 +00:00
|
|
|
b.c, err = client.Connect(addr, b.cfg.User, b.cfg.Password, "", func(c *client.Conn) {
|
|
|
|
c.SetTLSConfig(b.cfg.TLSConfig)
|
2017-02-12 11:13:54 +00:00
|
|
|
})
|
2016-06-16 09:15:56 +00:00
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
if len(b.cfg.Charset) != 0 {
|
|
|
|
b.c.SetCharset(b.cfg.Charset)
|
|
|
|
}
|
|
|
|
|
|
|
|
//set read timeout
|
|
|
|
if b.cfg.ReadTimeout > 0 {
|
|
|
|
b.c.SetReadDeadline(time.Now().Add(b.cfg.ReadTimeout))
|
|
|
|
}
|
|
|
|
|
|
|
|
if b.cfg.RecvBufferSize > 0 {
|
|
|
|
if tcp, ok := b.c.Conn.Conn.(*net.TCPConn); ok {
|
|
|
|
tcp.SetReadBuffer(b.cfg.RecvBufferSize)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// kill last connection id
|
|
|
|
if b.lastConnectionID > 0 {
|
|
|
|
cmd := fmt.Sprintf("KILL %d", b.lastConnectionID)
|
|
|
|
if _, err := b.c.Execute(cmd); err != nil {
|
|
|
|
log.Errorf("kill connection %d error %v", b.lastConnectionID, err)
|
|
|
|
// Unknown thread id
|
|
|
|
if code := ErrorCode(err.Error()); code != ER_NO_SUCH_THREAD {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
log.Infof("kill last connection id %d", b.lastConnectionID)
|
|
|
|
}
|
|
|
|
|
|
|
|
// save last last connection id for kill
|
|
|
|
b.lastConnectionID = b.c.GetConnectionID()
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
//for mysql 5.6+, binlog has a crc32 checksum
|
|
|
|
//before mysql 5.6, this will not work, don't matter.:-)
|
|
|
|
if r, err := b.c.Execute("SHOW GLOBAL VARIABLES LIKE 'BINLOG_CHECKSUM'"); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
} else {
|
|
|
|
s, _ := r.GetString(0, 1)
|
|
|
|
if s != "" {
|
|
|
|
// maybe CRC32 or NONE
|
|
|
|
|
|
|
|
// mysqlbinlog.cc use NONE, see its below comments:
|
|
|
|
// Make a notice to the server that this client
|
|
|
|
// is checksum-aware. It does not need the first fake Rotate
|
|
|
|
// necessary checksummed.
|
|
|
|
// That preference is specified below.
|
|
|
|
|
|
|
|
if _, err = b.c.Execute(`SET @master_binlog_checksum='NONE'`); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// if _, err = b.c.Execute(`SET @master_binlog_checksum=@@global.binlog_checksum`); err != nil {
|
|
|
|
// return errors.Trace(err)
|
|
|
|
// }
|
|
|
|
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.cfg.Flavor == MariaDBFlavor {
|
|
|
|
// Refer https://github.com/alibaba/canal/wiki/BinlogChange(MariaDB5&10)
|
|
|
|
// Tell the server that we understand GTIDs by setting our slave capability
|
|
|
|
// to MARIA_SLAVE_CAPABILITY_GTID = 4 (MariaDB >= 10.0.1).
|
|
|
|
if _, err := b.c.Execute("SET @mariadb_slave_capability=4"); err != nil {
|
|
|
|
return errors.Errorf("failed to set @mariadb_slave_capability=4: %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
if b.cfg.HeartbeatPeriod > 0 {
|
|
|
|
_, err = b.c.Execute(fmt.Sprintf("SET @master_heartbeat_period=%d;", b.cfg.HeartbeatPeriod))
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed to set @master_heartbeat_period=%d, err: %v", b.cfg.HeartbeatPeriod, err)
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
if err = b.writeRegisterSlaveCommand(); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
if _, err = b.c.ReadOKPacket(); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
func (b *BinlogSyncer) enableSemiSync() error {
|
2017-02-12 11:13:54 +00:00
|
|
|
if !b.cfg.SemiSyncEnabled {
|
|
|
|
return nil
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
if r, err := b.c.Execute("SHOW VARIABLES LIKE 'rpl_semi_sync_master_enabled';"); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
} else {
|
|
|
|
s, _ := r.GetString(0, 1)
|
|
|
|
if s != "ON" {
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Errorf("master does not support semi synchronous replication, use no semi-sync")
|
|
|
|
b.cfg.SemiSyncEnabled = false
|
|
|
|
return nil
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
_, err := b.c.Execute(`SET @rpl_semi_sync_slave = 1;`)
|
|
|
|
if err != nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
return errors.Trace(err)
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
2017-02-12 11:13:54 +00:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) prepare() error {
|
|
|
|
if b.isClosed() {
|
|
|
|
return errors.Trace(ErrSyncClosed)
|
|
|
|
}
|
|
|
|
|
|
|
|
if err := b.registerSlave(); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
if err := b.enableSemiSync(); err != nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) startDumpStream() *BinlogStreamer {
|
|
|
|
b.running = true
|
|
|
|
|
|
|
|
s := newBinlogStreamer()
|
|
|
|
|
|
|
|
b.wg.Add(1)
|
|
|
|
go b.onStream(s)
|
|
|
|
return s
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
// GetNextPosition returns the next position of the syncer
|
|
|
|
func (b *BinlogSyncer) GetNextPosition() Position {
|
|
|
|
return b.nextPos
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// StartSync starts syncing from the `pos` position.
|
2016-06-16 09:15:56 +00:00
|
|
|
func (b *BinlogSyncer) StartSync(pos Position) (*BinlogStreamer, error) {
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Infof("begin to sync binlog from position %s", pos)
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
b.m.Lock()
|
|
|
|
defer b.m.Unlock()
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.running {
|
|
|
|
return nil, errors.Trace(errSyncRunning)
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if err := b.prepareSyncPos(pos); err != nil {
|
|
|
|
return nil, errors.Trace(err)
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
return b.startDumpStream(), nil
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// StartSyncGTID starts syncing from the `gset` GTIDSet.
|
|
|
|
func (b *BinlogSyncer) StartSyncGTID(gset GTIDSet) (*BinlogStreamer, error) {
|
2019-01-01 08:57:46 +00:00
|
|
|
log.Infof("begin to sync binlog from GTID set %s", gset)
|
|
|
|
|
|
|
|
b.gset = gset
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
b.m.Lock()
|
|
|
|
defer b.m.Unlock()
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.running {
|
|
|
|
return nil, errors.Trace(errSyncRunning)
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if err := b.prepare(); err != nil {
|
|
|
|
return nil, errors.Trace(err)
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
var err error
|
2019-01-01 08:57:46 +00:00
|
|
|
switch b.cfg.Flavor {
|
|
|
|
case MariaDBFlavor:
|
|
|
|
err = b.writeBinlogDumpMariadbGTIDCommand(gset)
|
|
|
|
default:
|
2017-02-12 11:13:54 +00:00
|
|
|
// default use MySQL
|
2016-06-16 09:15:56 +00:00
|
|
|
err = b.writeBinlogDumpMysqlGTIDCommand(gset)
|
|
|
|
}
|
|
|
|
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return b.startDumpStream(), nil
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
func (b *BinlogSyncer) writeBinlogDumpCommand(p Position) error {
|
2016-06-16 09:15:56 +00:00
|
|
|
b.c.ResetSequence()
|
|
|
|
|
|
|
|
data := make([]byte, 4+1+4+2+4+len(p.Name))
|
|
|
|
|
|
|
|
pos := 4
|
|
|
|
data[pos] = COM_BINLOG_DUMP
|
|
|
|
pos++
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint32(data[pos:], p.Pos)
|
|
|
|
pos += 4
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint16(data[pos:], BINLOG_DUMP_NEVER_STOP)
|
|
|
|
pos += 2
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
binary.LittleEndian.PutUint32(data[pos:], b.cfg.ServerID)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += 4
|
|
|
|
|
|
|
|
copy(data[pos:], p.Name)
|
|
|
|
|
|
|
|
return b.c.WritePacket(data)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) writeBinlogDumpMysqlGTIDCommand(gset GTIDSet) error {
|
2019-01-01 08:57:46 +00:00
|
|
|
p := Position{Name: "", Pos: 4}
|
2016-06-16 09:15:56 +00:00
|
|
|
gtidData := gset.Encode()
|
|
|
|
|
|
|
|
b.c.ResetSequence()
|
|
|
|
|
|
|
|
data := make([]byte, 4+1+2+4+4+len(p.Name)+8+4+len(gtidData))
|
|
|
|
pos := 4
|
|
|
|
data[pos] = COM_BINLOG_DUMP_GTID
|
|
|
|
pos++
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint16(data[pos:], 0)
|
|
|
|
pos += 2
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
binary.LittleEndian.PutUint32(data[pos:], b.cfg.ServerID)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += 4
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint32(data[pos:], uint32(len(p.Name)))
|
|
|
|
pos += 4
|
|
|
|
|
|
|
|
n := copy(data[pos:], p.Name)
|
|
|
|
pos += n
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint64(data[pos:], uint64(p.Pos))
|
|
|
|
pos += 8
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint32(data[pos:], uint32(len(gtidData)))
|
|
|
|
pos += 4
|
|
|
|
n = copy(data[pos:], gtidData)
|
|
|
|
pos += n
|
|
|
|
|
|
|
|
data = data[0:pos]
|
|
|
|
|
|
|
|
return b.c.WritePacket(data)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) writeBinlogDumpMariadbGTIDCommand(gset GTIDSet) error {
|
|
|
|
// Copy from vitess
|
|
|
|
|
|
|
|
startPos := gset.String()
|
|
|
|
|
|
|
|
// Set the slave_connect_state variable before issuing COM_BINLOG_DUMP to
|
|
|
|
// provide the start position in GTID form.
|
|
|
|
query := fmt.Sprintf("SET @slave_connect_state='%s'", startPos)
|
|
|
|
|
|
|
|
if _, err := b.c.Execute(query); err != nil {
|
|
|
|
return errors.Errorf("failed to set @slave_connect_state='%s': %v", startPos, err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Real slaves set this upon connecting if their gtid_strict_mode option was
|
|
|
|
// enabled. We always use gtid_strict_mode because we need it to make our
|
|
|
|
// internal GTID comparisons safe.
|
|
|
|
if _, err := b.c.Execute("SET @slave_gtid_strict_mode=1"); err != nil {
|
|
|
|
return errors.Errorf("failed to set @slave_gtid_strict_mode=1: %v", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Since we use @slave_connect_state, the file and position here are ignored.
|
2019-01-01 08:57:46 +00:00
|
|
|
return b.writeBinlogDumpCommand(Position{Name: "", Pos: 0})
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// localHostname returns the hostname that register slave would register as.
|
|
|
|
func (b *BinlogSyncer) localHostname() string {
|
|
|
|
if len(b.cfg.Localhost) == 0 {
|
|
|
|
h, _ := os.Hostname()
|
|
|
|
return h
|
|
|
|
}
|
|
|
|
return b.cfg.Localhost
|
|
|
|
}
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
func (b *BinlogSyncer) writeRegisterSlaveCommand() error {
|
|
|
|
b.c.ResetSequence()
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
hostname := b.localHostname()
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
// This should be the name of slave host not the host we are connecting to.
|
2017-02-12 11:13:54 +00:00
|
|
|
data := make([]byte, 4+1+4+1+len(hostname)+1+len(b.cfg.User)+1+len(b.cfg.Password)+2+4+4)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos := 4
|
|
|
|
|
|
|
|
data[pos] = COM_REGISTER_SLAVE
|
|
|
|
pos++
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
binary.LittleEndian.PutUint32(data[pos:], b.cfg.ServerID)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += 4
|
|
|
|
|
|
|
|
// This should be the name of slave hostname not the host we are connecting to.
|
|
|
|
data[pos] = uint8(len(hostname))
|
|
|
|
pos++
|
|
|
|
n := copy(data[pos:], hostname)
|
|
|
|
pos += n
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
data[pos] = uint8(len(b.cfg.User))
|
2016-06-16 09:15:56 +00:00
|
|
|
pos++
|
2017-02-12 11:13:54 +00:00
|
|
|
n = copy(data[pos:], b.cfg.User)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += n
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
data[pos] = uint8(len(b.cfg.Password))
|
2016-06-16 09:15:56 +00:00
|
|
|
pos++
|
2017-02-12 11:13:54 +00:00
|
|
|
n = copy(data[pos:], b.cfg.Password)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += n
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
binary.LittleEndian.PutUint16(data[pos:], b.cfg.Port)
|
2016-06-16 09:15:56 +00:00
|
|
|
pos += 2
|
|
|
|
|
|
|
|
//replication rank, not used
|
|
|
|
binary.LittleEndian.PutUint32(data[pos:], 0)
|
|
|
|
pos += 4
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
// master ID, 0 is OK
|
|
|
|
binary.LittleEndian.PutUint32(data[pos:], 0)
|
2016-06-16 09:15:56 +00:00
|
|
|
|
|
|
|
return b.c.WritePacket(data)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) replySemiSyncACK(p Position) error {
|
|
|
|
b.c.ResetSequence()
|
|
|
|
|
|
|
|
data := make([]byte, 4+1+8+len(p.Name))
|
|
|
|
pos := 4
|
|
|
|
// semi sync indicator
|
|
|
|
data[pos] = SemiSyncIndicator
|
|
|
|
pos++
|
|
|
|
|
|
|
|
binary.LittleEndian.PutUint64(data[pos:], uint64(p.Pos))
|
|
|
|
pos += 8
|
|
|
|
|
|
|
|
copy(data[pos:], p.Name)
|
|
|
|
|
|
|
|
err := b.c.WritePacket(data)
|
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
return nil
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
func (b *BinlogSyncer) retrySync() error {
|
|
|
|
b.m.Lock()
|
|
|
|
defer b.m.Unlock()
|
|
|
|
|
|
|
|
b.parser.Reset()
|
2019-01-01 08:57:46 +00:00
|
|
|
|
|
|
|
if b.gset != nil {
|
|
|
|
log.Infof("begin to re-sync from %s", b.gset.String())
|
|
|
|
if err := b.prepareSyncGTID(b.gset); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
log.Infof("begin to re-sync from %s", b.nextPos)
|
|
|
|
if err := b.prepareSyncPos(b.nextPos); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
2017-02-12 11:13:54 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) prepareSyncPos(pos Position) error {
|
|
|
|
// always start from position 4
|
|
|
|
if pos.Pos < 4 {
|
|
|
|
pos.Pos = 4
|
|
|
|
}
|
|
|
|
|
|
|
|
if err := b.prepare(); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
if err := b.writeBinlogDumpCommand(pos); err != nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
func (b *BinlogSyncer) prepareSyncGTID(gset GTIDSet) error {
|
|
|
|
var err error
|
|
|
|
|
|
|
|
if err = b.prepare(); err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
switch b.cfg.Flavor {
|
|
|
|
case MariaDBFlavor:
|
|
|
|
err = b.writeBinlogDumpMariadbGTIDCommand(gset)
|
|
|
|
default:
|
|
|
|
// default use MySQL
|
|
|
|
err = b.writeBinlogDumpMysqlGTIDCommand(gset)
|
|
|
|
}
|
|
|
|
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
func (b *BinlogSyncer) onStream(s *BinlogStreamer) {
|
|
|
|
defer func() {
|
|
|
|
if e := recover(); e != nil {
|
|
|
|
s.closeWithError(fmt.Errorf("Err: %v\n Stack: %s", e, Pstack()))
|
|
|
|
}
|
|
|
|
b.wg.Done()
|
|
|
|
}()
|
|
|
|
|
|
|
|
for {
|
|
|
|
data, err := b.c.ReadPacket()
|
|
|
|
if err != nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Error(err)
|
|
|
|
|
|
|
|
// we meet connection error, should re-connect again with
|
2019-01-01 08:57:46 +00:00
|
|
|
// last nextPos or nextGTID we got.
|
|
|
|
if len(b.nextPos.Name) == 0 && b.gset == nil {
|
2017-02-12 11:13:54 +00:00
|
|
|
// we can't get the correct position, close.
|
|
|
|
s.closeWithError(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-b.ctx.Done():
|
|
|
|
s.close()
|
|
|
|
return
|
|
|
|
case <-time.After(time.Second):
|
2019-01-01 08:57:46 +00:00
|
|
|
b.retryCount++
|
2017-02-12 11:13:54 +00:00
|
|
|
if err = b.retrySync(); err != nil {
|
2019-01-01 08:57:46 +00:00
|
|
|
if b.cfg.MaxReconnectAttempts > 0 && b.retryCount >= b.cfg.MaxReconnectAttempts {
|
|
|
|
log.Errorf("retry sync err: %v, exceeded max retries (%d)", err, b.cfg.MaxReconnectAttempts)
|
|
|
|
s.closeWithError(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Errorf("retry sync err: %v, wait 1s and retry again", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
break
|
|
|
|
}
|
|
|
|
|
|
|
|
// we connect the server and begin to re-sync again.
|
|
|
|
continue
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
//set read timeout
|
|
|
|
if b.cfg.ReadTimeout > 0 {
|
|
|
|
b.c.SetReadDeadline(time.Now().Add(b.cfg.ReadTimeout))
|
|
|
|
}
|
|
|
|
|
|
|
|
// Reset retry count on successful packet receieve
|
|
|
|
b.retryCount = 0
|
|
|
|
|
2016-06-16 09:15:56 +00:00
|
|
|
switch data[0] {
|
|
|
|
case OK_HEADER:
|
|
|
|
if err = b.parseEvent(s, data); err != nil {
|
|
|
|
s.closeWithError(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
case ERR_HEADER:
|
|
|
|
err = b.c.HandleErrorPacket(data)
|
|
|
|
s.closeWithError(err)
|
|
|
|
return
|
2017-02-12 11:13:54 +00:00
|
|
|
case EOF_HEADER:
|
|
|
|
// Refer http://dev.mysql.com/doc/internals/en/packet-EOF_Packet.html
|
|
|
|
// In the MySQL client/server protocol, EOF and OK packets serve the same purpose.
|
|
|
|
// Some users told me that they received EOF packet here, but I don't know why.
|
|
|
|
// So we only log a message and retry ReadPacket.
|
|
|
|
log.Info("receive EOF packet, retry ReadPacket")
|
|
|
|
continue
|
2016-06-16 09:15:56 +00:00
|
|
|
default:
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Errorf("invalid stream header %c", data[0])
|
|
|
|
continue
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (b *BinlogSyncer) parseEvent(s *BinlogStreamer, data []byte) error {
|
|
|
|
//skip OK byte, 0x00
|
|
|
|
data = data[1:]
|
|
|
|
|
|
|
|
needACK := false
|
2017-02-12 11:13:54 +00:00
|
|
|
if b.cfg.SemiSyncEnabled && (data[0] == SemiSyncIndicator) {
|
2016-06-16 09:15:56 +00:00
|
|
|
needACK = (data[1] == 0x01)
|
|
|
|
//skip semi sync header
|
|
|
|
data = data[2:]
|
|
|
|
}
|
|
|
|
|
2019-01-01 08:57:46 +00:00
|
|
|
e, err := b.parser.Parse(data)
|
2016-06-16 09:15:56 +00:00
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
|
2017-02-12 11:13:54 +00:00
|
|
|
if e.Header.LogPos > 0 {
|
|
|
|
// Some events like FormatDescriptionEvent return 0, ignore.
|
|
|
|
b.nextPos.Pos = e.Header.LogPos
|
|
|
|
}
|
2019-01-01 08:57:46 +00:00
|
|
|
switch event := e.Event.(type) {
|
|
|
|
case *RotateEvent:
|
|
|
|
b.nextPos.Name = string(event.NextLogName)
|
|
|
|
b.nextPos.Pos = uint32(event.Position)
|
2017-02-12 11:13:54 +00:00
|
|
|
log.Infof("rotate to %s", b.nextPos)
|
2019-01-01 08:57:46 +00:00
|
|
|
case *GTIDEvent:
|
|
|
|
if b.gset == nil {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
u, _ := uuid.FromBytes(event.SID)
|
|
|
|
err := b.gset.Update(fmt.Sprintf("%s:%d", u.String(), event.GNO))
|
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
case *MariadbGTIDEvent:
|
|
|
|
if b.gset == nil {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
GTID := event.GTID
|
|
|
|
err := b.gset.Update(fmt.Sprintf("%d-%d-%d", GTID.DomainID, GTID.ServerID, GTID.SequenceNumber))
|
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
case *XIDEvent:
|
|
|
|
event.GSet = b.getGtidSet()
|
|
|
|
case *QueryEvent:
|
|
|
|
event.GSet = b.getGtidSet()
|
2016-06-16 09:15:56 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
needStop := false
|
|
|
|
select {
|
|
|
|
case s.ch <- e:
|
2017-02-12 11:13:54 +00:00
|
|
|
case <-b.ctx.Done():
|
2016-06-16 09:15:56 +00:00
|
|
|
needStop = true
|
|
|
|
}
|
|
|
|
|
|
|
|
if needACK {
|
|
|
|
err := b.replySemiSyncACK(b.nextPos)
|
|
|
|
if err != nil {
|
|
|
|
return errors.Trace(err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if needStop {
|
|
|
|
return errors.New("sync is been closing...")
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
2019-01-01 08:57:46 +00:00
|
|
|
|
|
|
|
func (b *BinlogSyncer) getGtidSet() GTIDSet {
|
|
|
|
if b.gset == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
return b.gset.Clone()
|
|
|
|
}
|
|
|
|
|
|
|
|
// LastConnectionID returns last connectionID.
|
|
|
|
func (b *BinlogSyncer) LastConnectionID() uint32 {
|
|
|
|
return b.lastConnectionID
|
|
|
|
}
|