Documentation ¶
Index ¶
- Constants
- Variables
- func ConcurrentMap(concurrency, n int, fun MapFunc) error
- func DirectoryList(cnf *Mycnf) []string
- func Init(mt *Mysqld, mysqlWaitTime time.Duration) error
- func MakeMycnf(mycnf *Mycnf, cnfFiles []string) (string, error)
- func MySQLReplicationLag(mysqld *Mysqld, allowedLagInSeconds int) health.Reporter
- func MycnfFile(uid uint32) string
- func SanityCheckManifests(ssms []*SplitSnapshotManifest) error
- func Shutdown(mt *Mysqld, waitForMysqld bool, mysqlWaitTime time.Duration) error
- func SnapshotDir(uid uint32) string
- func Start(mt *Mysqld, mysqlWaitTime time.Duration) error
- func StartReplicationCommands(mysqld *Mysqld, replState *proto.ReplicationState) ([]string, error)
- func TabletDir(uid uint32) string
- func Teardown(mt *Mysqld, force bool) error
- func TopLevelDirs() []string
- type FakeMysqlDaemon
- type MapFunc
- type Mycnf
- type MysqlDaemon
- type MysqlFlavor
- type Mysqld
- func (mysqld *Mysqld) Addr() string
- func (mysqld *Mysqld) ApplySchemaChange(dbName string, change *proto.SchemaChange) (*proto.SchemaChangeResult, error)
- func (mysqld *Mysqld) BinlogInfo(groupId int64) (rp *proto.ReplicationPosition, err error)
- func (mysqld *Mysqld) BreakSlaves() error
- func (mysqld *Mysqld) CheckReplication(timeCheck int64) error
- func (mt *Mysqld) Cnf() *Mycnf
- func (mysqld *Mysqld) CreateMultiSnapshot(keyRanges []key.KeyRange, dbName, keyName string, keyType key.KeyspaceIdType, ...) (snapshotManifestFilenames []string, err error)
- func (mysqld *Mysqld) CreateSnapshot(dbName, sourceAddr string, allowHierarchicalReplication bool, concurrency int, ...) (snapshotManifestUrlPath string, slaveStartRequired, readOnly bool, err error)
- func (mysqld *Mysqld) DemoteMaster() (*proto.ReplicationPosition, error)
- func (mysqld *Mysqld) ExecuteMysqlCommand(sql string) error
- func (mysqld *Mysqld) FindSlaves() ([]string, error)
- func (mysqld *Mysqld) FindVtDatabases() ([]string, error)
- func (mysqld *Mysqld) GetColumns(dbName, table string) ([]string, error)
- func (mysqld *Mysqld) GetMasterAddr() (string, error)
- func (mysqld *Mysqld) GetMysqlPort() (int, error)
- func (mysqld *Mysqld) GetPermissions() (*proto.Permissions, error)
- func (mysqld *Mysqld) GetPrimaryKeyColumns(dbName, table string) ([]string, error)
- func (mysqld *Mysqld) GetSchema(dbName string, tables []string, includeViews bool) (*proto.SchemaDefinition, error)
- func (mysqld *Mysqld) IpAddr() string
- func (mysqld *Mysqld) IsReadOnly() (bool, error)
- func (mysqld *Mysqld) MasterStatus() (rp *proto.ReplicationPosition, err error)
- func (mysqld *Mysqld) MultiRestore(destinationDbName string, keyRanges []key.KeyRange, sourceAddrs []*url.URL, ...) (err error)
- func (mysqld *Mysqld) MycnfPath() string
- func (mysqld *Mysqld) Port() int
- func (mysqld *Mysqld) PreflightSchemaChange(dbName string, change string) (*proto.SchemaChangeResult, error)
- func (mysqld *Mysqld) PromoteSlave(setReadWrite bool, hookExtraEnv map[string]string) (replicationState *proto.ReplicationState, ...)
- func (mysqld *Mysqld) ReparentPosition(slavePosition *proto.ReplicationPosition) (rs *proto.ReplicationState, waitPosition *proto.ReplicationPosition, ...)
- func (mysqld *Mysqld) RestartSlave(replicationState *proto.ReplicationState, ...) error
- func (mysqld *Mysqld) RestoreFromSnapshot(snapshotManifest *SnapshotManifest, fetchConcurrency, fetchRetryCount int, ...) error
- func (mysqld *Mysqld) SetReadOnly(on bool) error
- func (mysqld *Mysqld) SlaveStatus() (*proto.ReplicationPosition, error)
- func (mysqld *Mysqld) SnapshotSourceEnd(slaveStartRequired, readOnly, deleteSnapshot bool, ...) error
- func (mysqld *Mysqld) StartSlave(hookExtraEnv map[string]string) error
- func (mysqld *Mysqld) StopSlave(hookExtraEnv map[string]string) error
- func (mysqld *Mysqld) ValidateCloneTarget(hookExtraEnv map[string]string) error
- func (mysqld *Mysqld) ValidateSnapshotPath() error
- func (mysqld *Mysqld) WaitBlpPos(bp *proto.BlpPosition, waitTimeout time.Duration) error
- func (mysqld *Mysqld) WaitForMinimumReplicationPosition(groupId int64, waitTimeout time.Duration) (err error)
- func (mysqld *Mysqld) WaitForSlave(maxLag int) (err error)
- func (mysqld *Mysqld) WaitForSlaveStart(slaveStartDeadline int) (err error)
- func (mysqld *Mysqld) WaitMasterPos(rp *proto.ReplicationPosition, waitTimeout time.Duration) error
- type SnapshotFile
- type SnapshotFiles
- type SnapshotManifest
- type SplitSnapshotManifest
- type VtReplParams
Constants ¶
const (
MysqlWaitTime = 120 * time.Second // default number of seconds to wait
)
const (
SlaveStartDeadline = 30
)
const (
SnapshotManifestFile = "snapshot_manifest.json"
)
const (
SnapshotURLPath = "/snapshot"
)
Variables ¶
var ( ErrNotSlave = errors.New("no slave status") ErrNotMaster = errors.New("no master status") )
Functions ¶
func ConcurrentMap ¶
ConcurrentMap applies fun in a concurrent manner on integers from 0 to n-1 (they are assumed to be indexes of some slice containing items to be processed). The first error returned by a fun application will returned (subsequent errors will only be logged). It will use concurrency goroutines.
func DirectoryList ¶
func MySQLReplicationLag ¶
MySQLReplication lag returns a reporter that reports the MySQL replication lag. It uses the key "replication_lag".
func SanityCheckManifests ¶
func SanityCheckManifests(ssms []*SplitSnapshotManifest) error
SanityCheckManifests checks if the ssms can be restored together.
func Shutdown ¶
waitForMysqld: should the function block until mysqld has stopped?
This can actually take a *long* time if the buffer cache needs to be fully flushed - on the order of 20-30 minutes.
func SnapshotDir ¶
func StartReplicationCommands ¶
func StartReplicationCommands(mysqld *Mysqld, replState *proto.ReplicationState) ([]string, error)
func TopLevelDirs ¶
func TopLevelDirs() []string
Types ¶
type FakeMysqlDaemon ¶
type FakeMysqlDaemon struct { // will be returned by GetMasterAddr(). Set to "" to return // ErrNotSlave, or to "ERROR" to return an error. MasterAddr string // will be returned by GetMysqlPort(). Set to -1 to return an error. MysqlPort int }
FakeMysqlDaemon implements MysqlDaemon and allows the user to fake everything.
func (*FakeMysqlDaemon) GetMasterAddr ¶
func (fmd *FakeMysqlDaemon) GetMasterAddr() (string, error)
func (*FakeMysqlDaemon) GetMysqlPort ¶
func (fmd *FakeMysqlDaemon) GetMysqlPort() (int, error)
type Mycnf ¶
type Mycnf struct { ServerId uint32 MysqlPort int DataDir string InnodbDataHomeDir string InnodbLogGroupHomeDir string SocketFile string StartKey string EndKey string ErrorLogPath string SlowLogPath string RelayLogPath string RelayLogIndexPath string RelayLogInfoPath string BinLogPath string MasterInfoFile string PidFile string TmpDir string SlaveLoadTmpDir string // contains filtered or unexported fields }
func NewMycnf ¶
func NewMycnf(uid uint32, mysqlPort int, vtRepl VtReplParams) *Mycnf
NewMycnf fills the Mycnf structure with vt root paths and derived values. This is used to fill out the cnfTemplate values and generate my.cnf. uid is a unique id for a particular tablet - it must be unique within the tabletservers deployed within a keyspace, lest there be collisions on disk. mysqldPort needs to be unique per instance per machine.
type MysqlDaemon ¶
type MysqlDaemon interface { // GetMasterAddr returns the mysql master address, as shown by // 'show slave status'. GetMasterAddr() (string, error) // GetMysqlPort returns the current port mysql is listening on. GetMysqlPort() (int, error) }
MysqlDaemon is the interface we use for abstracting Mysqld.
type MysqlFlavor ¶
type MysqlFlavor interface { // MasterStatus fills in the ReplicationPosition structure. // It has two components: the result of a standard 'SHOW MASTER STATUS' // and the corresponding transaction group id. MasterStatus(mysqld *Mysqld) (*proto.ReplicationPosition, error) // PromoteSlaveCommands returns the commands to run to change // a slave into a master PromoteSlaveCommands() []string }
MysqlFlavor is the abstract interface for a flavor.
type Mysqld ¶
type Mysqld struct { TabletDir string SnapshotDir string // contains filtered or unexported fields }
func (*Mysqld) ApplySchemaChange ¶
func (mysqld *Mysqld) ApplySchemaChange(dbName string, change *proto.SchemaChange) (*proto.SchemaChangeResult, error)
func (*Mysqld) BinlogInfo ¶
func (mysqld *Mysqld) BinlogInfo(groupId int64) (rp *proto.ReplicationPosition, err error)
mysql> show binlog info for 5\G *************************** 1. row *************************** Log_name: vt-0000041983-bin.000001 Pos: 1194 Server_ID: 41983
func (*Mysqld) BreakSlaves ¶
Force all slaves to error and stop. This is extreme, but helpful for emergencies and tests. Insert a row, block the propagation of its subsequent delete and reinsert it. This forces a failure on slaves only.
func (*Mysqld) CheckReplication ¶
Check for the magic row inserted under controlled reparenting.
func (*Mysqld) CreateMultiSnapshot ¶
func (mysqld *Mysqld) CreateMultiSnapshot(keyRanges []key.KeyRange, dbName, keyName string, keyType key.KeyspaceIdType, sourceAddr string, allowHierarchicalReplication bool, snapshotConcurrency int, tables []string, skipSlaveRestart bool, maximumFilesize uint64, hookExtraEnv map[string]string) (snapshotManifestFilenames []string, err error)
CreateMultiSnapshot create snapshots of the data.
- for a resharding snapshot, keyRanges+keyName+keyType are set, and tables is empty. This action will create multiple snapshots, one per keyRange.
- for a vertical split, tables is set, keyRanges = [KeyRange{}] and keyName+keyType are empty. It will create a single snapshot of the contents of the tables.
Note combinations of table subset and keyranges are not supported.
func (*Mysqld) CreateSnapshot ¶
func (mysqld *Mysqld) CreateSnapshot(dbName, sourceAddr string, allowHierarchicalReplication bool, concurrency int, serverMode bool, hookExtraEnv map[string]string) (snapshotManifestUrlPath string, slaveStartRequired, readOnly bool, err error)
This function runs on the machine acting as the source for the clone.
Check master/slave status and determine restore needs. If this instance is a slave, stop replication, otherwise place in read-only mode. Record replication position. Shutdown mysql Check paths for storing data
Depending on the serverMode flag, we do the following: serverMode = false:
Compress /vt/vt_[0-9a-f]+/data/vt_.+ Compute hash (of compressed files, as we serve .gz files here) Place in /vt/clone_src where they will be served by http server (not rpc) Restart mysql
serverMode = true:
Make symlinks for /vt/vt_[0-9a-f]+/data/vt_.+ to innodb files Compute hash (of uncompressed files, as we serve uncompressed files) Place symlinks in /vt/clone_src where they will be served by http server Leave mysql stopped, return slaveStartRequired, readOnly
func (*Mysqld) DemoteMaster ¶
func (mysqld *Mysqld) DemoteMaster() (*proto.ReplicationPosition, error)
if the master is still alive, then we need to demote it gracefully make it read-only, flush the writes and get the position
func (*Mysqld) ExecuteMysqlCommand ¶
executes some SQL commands using a mysql command line interface process
func (*Mysqld) FindSlaves ¶
Get IP addresses for all currently connected slaves.
func (*Mysqld) FindVtDatabases ¶
func (*Mysqld) GetColumns ¶
GetColumns returns the columns of table.
func (*Mysqld) GetMasterAddr ¶
func (*Mysqld) GetMysqlPort ¶
func (*Mysqld) GetPermissions ¶
func (mysqld *Mysqld) GetPermissions() (*proto.Permissions, error)
func (*Mysqld) GetPrimaryKeyColumns ¶
GetPrimaryKeyColumns returns the primary key columns of table.
func (*Mysqld) GetSchema ¶
func (mysqld *Mysqld) GetSchema(dbName string, tables []string, includeViews bool) (*proto.SchemaDefinition, error)
GetSchema returns the schema for database for tables listed in tables. If tables is empty, return the schema for all tables.
func (*Mysqld) IsReadOnly ¶
func (*Mysqld) MasterStatus ¶
func (mysqld *Mysqld) MasterStatus() (rp *proto.ReplicationPosition, err error)
func (*Mysqld) MultiRestore ¶
func (mysqld *Mysqld) MultiRestore(destinationDbName string, keyRanges []key.KeyRange, sourceAddrs []*url.URL, snapshotConcurrency, fetchConcurrency, insertTableConcurrency, fetchRetryCount int, strategy string) (err error)
MultiRestore is the main entry point for multi restore.
- If the strategy contains the string 'writeBinLogs' then we will also write to the binary logs.
- If the strategy contains the command 'populateBlpCheckpoint' then we will populate the blp_checkpoint table with master positions to start from
func (*Mysqld) PreflightSchemaChange ¶
func (*Mysqld) PromoteSlave ¶
func (mysqld *Mysqld) PromoteSlave(setReadWrite bool, hookExtraEnv map[string]string) (replicationState *proto.ReplicationState, waitPosition *proto.ReplicationPosition, timePromoted int64, err error)
setReadWrite: set the new master in read-write mode.
replicationState: info slaves need to reparent themselves waitPosition: slaves can wait for this position when restarting replication timePromoted: this timestamp (unix nanoseconds) is inserted into _vt.replication_log to verify the replication config
func (*Mysqld) ReparentPosition ¶
func (mysqld *Mysqld) ReparentPosition(slavePosition *proto.ReplicationPosition) (rs *proto.ReplicationState, waitPosition *proto.ReplicationPosition, reparentTime int64, err error)
Return a replication state that will reparent a slave to the correct master for a specified position.
func (*Mysqld) RestartSlave ¶
func (mysqld *Mysqld) RestartSlave(replicationState *proto.ReplicationState, waitPosition *proto.ReplicationPosition, timeCheck int64) error
func (*Mysqld) RestoreFromSnapshot ¶
func (mysqld *Mysqld) RestoreFromSnapshot(snapshotManifest *SnapshotManifest, fetchConcurrency, fetchRetryCount int, dontWaitForSlaveStart bool, hookExtraEnv map[string]string) error
This piece runs on the presumably empty machine acting as the target in the create replica action.
validate target (self) shutdown_mysql() create temp data directory /vt/target/vt_<keyspace> copy compressed data files via HTTP verify hash of compressed files uncompress into /vt/vt_<target-uid>/data/vt_<keyspace> start_mysql() clean up compressed files
func (*Mysqld) SetReadOnly ¶
func (*Mysqld) SlaveStatus ¶
func (mysqld *Mysqld) SlaveStatus() (*proto.ReplicationPosition, error)
func (*Mysqld) SnapshotSourceEnd ¶
func (*Mysqld) ValidateCloneTarget ¶
func (*Mysqld) ValidateSnapshotPath ¶
Helper function to make sure we can write to the local snapshot area, before we actually do any action (can be used for both partial and full snapshots)
func (*Mysqld) WaitBlpPos ¶
func (*Mysqld) WaitForMinimumReplicationPosition ¶
func (*Mysqld) WaitForSlave ¶
func (*Mysqld) WaitForSlaveStart ¶
func (*Mysqld) WaitMasterPos ¶
type SnapshotFile ¶
SnapshotFile describes a file to serve. 'Path' is the path component of the URL. SnapshotManifest.Addr is the host+port component of the URL. If path ends in '.gz', it is compressed. Size and Hash are computed on the Path itself if TableName is set, this file belongs to that table
type SnapshotFiles ¶
type SnapshotFiles []SnapshotFile
func (SnapshotFiles) Len ¶
func (s SnapshotFiles) Len() int
sort.Interface we sort by descending file size
func (SnapshotFiles) Less ¶
func (s SnapshotFiles) Less(i, j int) bool
func (SnapshotFiles) Swap ¶
func (s SnapshotFiles) Swap(i, j int)
type SnapshotManifest ¶
type SnapshotManifest struct { Addr string // this is the address of the tabletserver, not mysql DbName string Files SnapshotFiles ReplicationState *proto.ReplicationState MasterState *proto.ReplicationState }
a SnapshotManifest describes multiple SnapshotFiles and where to get them from.
func ReadSnapshotManifest ¶
func ReadSnapshotManifest(filename string) (*SnapshotManifest, error)
type SplitSnapshotManifest ¶
type SplitSnapshotManifest struct { // Source describes the files and our tablet Source *SnapshotManifest // KeyRange describes the data present in this snapshot // When splitting 40-80 into 40-60 and 60-80, this would // have 40-60 for instance. KeyRange key.KeyRange // The schema for this server SchemaDefinition *proto.SchemaDefinition }
func NewSplitSnapshotManifest ¶
func NewSplitSnapshotManifest(myAddr, myMysqlAddr, masterAddr, dbName string, files []SnapshotFile, pos, myMasterPos *proto.ReplicationPosition, keyRange key.KeyRange, sd *proto.SchemaDefinition) (*SplitSnapshotManifest, error)
NewSplitSnapshotManifest creates a new SplitSnapshotManifest. myAddr and myMysqlAddr are the local server addresses. masterAddr is the address of the server to use as master. pos is the replication position to use on that master. myMasterPos is the local server master position