inst

package
v1.4.191 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Jul 3, 2015 License: Apache-2.0 Imports: 18 Imported by: 0

Documentation

Index

Constants

View Source
const (
	NoProblem                                 AnalysisCode = "NoProblem"
	DeadMasterWithoutSlaves                                = "DeadMasterWithoutSlaves"
	DeadMaster                                             = "DeadMaster"
	DeadMasterAndSlaves                                    = "DeadMasterAndSlaves"
	DeadMasterAndSomeSlaves                                = "DeadMasterAndSomeSlaves"
	UnreachableMaster                                      = "UnreachableMaster"
	AllMasterSlavesNotReplicating                          = "AllMasterSlavesNotReplicating"
	MasterWithoutSlaves                                    = "MasterWithoutSlaves"
	DeadCoMaster                                           = "DeadCoMaster"
	UnreachableCoMaster                                    = "UnreachableCoMaster"
	AllCoMasterSlavesNotReplicating                        = "AllCoMasterSlavesNotReplicating"
	DeadIntermediateMaster                                 = "DeadIntermediateMaster"
	DeadIntermediateMasterAndSomeSlaves                    = "DeadIntermediateMasterAndSomeSlaves"
	UnreachableIntermediateMaster                          = "UnreachableIntermediateMaster"
	AllIntermediateMasterSlavesNotReplicating              = "AllIntermediateMasterSlavesNotReplicating"
	FirstTierSlaveFailingToConnectToMaster                 = "FirstTierSlaveFailingToConnectToMaster"
	MaxscaleFailingToConnectToMaster                       = "MaxscaleFailingToConnectToMaster"
)

Variables

This section is empty.

Functions

func ASCIITopology

func ASCIITopology(instanceKey *InstanceKey, historyTimestampPattern string) (string, error)

ASCIITopology returns a string representation of the topology of given instance.

func ApplyClusterAlias

func ApplyClusterAlias(clusterInfo *ClusterInfo)

func ApplyPoolInstances

func ApplyPoolInstances(pool string, instancesList string) error

func AuditOperation

func AuditOperation(auditType string, instanceKey *InstanceKey, message string) error

AuditOperation creates and writes a new audit entry by given params

func BeginBoundedMaintenance

func BeginBoundedMaintenance(instanceKey *InstanceKey, owner string, reason string, durationSeconds uint) (int64, error)

BeginBoundedMaintenance will make new maintenance entry for given instanceKey.

func BeginDowntime

func BeginDowntime(instanceKey *InstanceKey, owner string, reason string, durationSeconds uint) error

BeginDowntime will make mark an instance as downtimed (or override existing downtime period)

func BeginMaintenance

func BeginMaintenance(instanceKey *InstanceKey, owner string, reason string) (int64, error)

BeginMaintenance will make new maintenance entry for given instanceKey. Maintenance time is unbounded

func DeleteInvalidHostnameResolves

func DeleteInvalidHostnameResolves() error

DeleteInvalidHostnameResolves removes invalid resolves. At this time these are: - infinite loop resolves (A->B and B->A), remove earlier mapping

func DeregisterHostnameUnresolve

func DeregisterHostnameUnresolve(instanceKey *InstanceKey) error

DeregisterHostnameUnresolve removes an unresovle entry

func EndDowntime

func EndDowntime(instanceKey *InstanceKey) error

EndDowntime will remove downtime flag from an instance

func EndMaintenance

func EndMaintenance(maintenanceToken int64) error

EndMaintenance will terminate an active maintenance via maintenanceToken

func EndMaintenanceByInstanceKey

func EndMaintenanceByInstanceKey(instanceKey *InstanceKey) error

EndMaintenanceByInstanceKey will terminate an active maintenance using given instanceKey as hint

func ExecDBWriteFunc

func ExecDBWriteFunc(f func() error) error

ExecDBWriteFunc chooses how to execute a write onto the database: whether synchronuously or not

func ExecInstance

func ExecInstance(instanceKey *InstanceKey, query string, args ...interface{}) (sql.Result, error)

ExecInstance executes a given query on the given MySQL topology instance

func ExecInstanceNoPrepare

func ExecInstanceNoPrepare(instanceKey *InstanceKey, query string, args ...interface{}) (sql.Result, error)

ExecInstanceNoPrepare executes a given query on the given MySQL topology instance, without using prepared statements

func ExecuteOnTopology

func ExecuteOnTopology(f func())

ExecuteOnTopology will execute given function while maintaining concurrency limit on topology servers. It is safe in the sense that we will not leak tokens.

func ExpireCandidateInstances

func ExpireCandidateInstances() error

RegisterCandidateInstance markes a given instance as suggested for successoring a master in the event of failover.

func ExpireDowntime

func ExpireDowntime() error

ExpireDowntime will remove the maintenance flag on old downtimes

func ExpireHostnameUnresolve

func ExpireHostnameUnresolve() error

ExpireHostnameUnresolve expires hostname_unresolve entries that haven't been updated recently.

func ExpireMaintenance

func ExpireMaintenance() error

ExpireMaintenance will remove the maintenance flag on old maintenances and on bounded maintenances

func FlushBinaryLogs

func FlushBinaryLogs(instanceKey *InstanceKey) error

FlushBinaryLogs attempts a 'FLUSH BINARY LOGS' statement on the given instance.

func ForgetExpiredHostnameResolves

func ForgetExpiredHostnameResolves() error

ForgetExpiredHostnameResolves

func ForgetInstance

func ForgetInstance(instanceKey *InstanceKey) error

ForgetInstance removes an instance entry from the orchestrator backed database. It may be auto-rediscovered through topology or requested for discovery by multiple means.

func ForgetLongUnseenInstances

func ForgetLongUnseenInstances() error

ForgetLongUnseenInstances will remove entries of all instacnes that have long since been last seen.

func ForgetUnseenInstancesDifferentlyResolved

func ForgetUnseenInstancesDifferentlyResolved() error

ForgetUnseenInstancesDifferentlyResolved will purge instances which are invalid, and whose hostname appears on the hostname_resolved table; this means some time in the past their hostname was unresovled, and now resovled to a different value; the old hostname is never accessed anymore and the old entry should be removed.

func GetCNAME

func GetCNAME(hostname string) (string, error)

GetCNAME resolves an IP or hostname into a normalized valid CNAME

func GetCandidateSlave

func GetCandidateSlave(masterKey *InstanceKey, forRematchPurposes bool) (*Instance, [](*Instance), [](*Instance), [](*Instance), error)

GetCandidateSlave chooses the best slave to promote given a (possibly dead) master

func GetClusterByAlias

func GetClusterByAlias(alias string) (string, error)

GetClusterByAlias returns the cluster name associated with given alias. The function returns with error when: - No cluster is associated with the alias - More than one cluster is associated with the alias

func GetClusterHeuristicLag

func GetClusterHeuristicLag(clusterName string) (int64, error)

GetClusterHeuristicLag returns a heuristic lag for a cluster, based on its OSC slaves

func GetMaintenanceOwner

func GetMaintenanceOwner() string

func HostnameResolveCache

func HostnameResolveCache() (map[string]*cache.Item, error)

func InjectUnseenMasters

func InjectUnseenMasters() error

InjectUnseenMasters will review masters of instances that are known to be replication, yet which are not listed in database_instance. Since their slaves are listed as replicating, we can assume that such masters actually do exist: we shall therefore inject them with minimal details into the database_instance table.

func InstanceIsMasterOf

func InstanceIsMasterOf(instance0, instance1 *Instance) bool

InstanceIsMasterOf checks whether an instance is the master of another

func InstancesAreSiblings

func InstancesAreSiblings(instance0, instance1 *Instance) bool

InstancesAreSiblings checks whether both instances are replicating from same master

func LoadHostnameResolveCacheFromDatabase

func LoadHostnameResolveCacheFromDatabase() error

func MatchBelow

func MatchBelow(instanceKey, otherKey *InstanceKey, requireInstanceMaintenance bool, requireOtherMaintenance bool) (*Instance, *BinlogCoordinates, error)

MatchBelow will attempt moving instance indicated by instanceKey below its the one indicated by otherKey. The refactoring is based on matching binlog entries, not on "classic" positions comparisons. The "other instance" could be the sibling of the moving instance any of its ancestors. It may actuall be a cousin of some sort (though unlikely). The only important thing is that the "other instance" is more advanced in replication than given instance.

func MatchUp

func MatchUp(instanceKey *InstanceKey, requireInstanceMaintenance bool, requireOtherMaintenance bool) (*Instance, *BinlogCoordinates, error)

MatchUp will move a slave up the replication chain, so that it becomes sibling of its master, via Pseudo-GTID

func MatchUpSlaves

func MatchUpSlaves(masterKey *InstanceKey, pattern string) ([](*Instance), *Instance, error, []error)

MatchUpSlaves will move all slaves of given master up the replication chain, so that they become siblings of their master. This should be called when the local master dies, and all its slaves are to be resurrected via Pseudo-GTID

func MoveUpSlaves

func MoveUpSlaves(instanceKey *InstanceKey, pattern string) ([](*Instance), *Instance, error, []error)

MoveUpSlaves will attempt moving up all slaves of a given instance, at the same time. Clock-time, this is fater than moving one at a time. However this means all slaves of the given instance, and the instance itself, will all stop replicating together.

func MultiMatchBelow

func MultiMatchBelow(slaves [](*Instance), belowKey *InstanceKey, slavesAlreadyStopped bool) ([](*Instance), *Instance, error, []error)

MultiMatchBelow will efficiently match multiple slaves below a given instance. It is assumed that all given slaves are siblings

func MultiMatchSlaves

func MultiMatchSlaves(masterKey *InstanceKey, belowKey *InstanceKey, pattern string) ([](*Instance), *Instance, error, []error)

MultiMatchSlaves will match (via pseudo-gtid) all slaves of given master below given instance.

func PopulateInstancesAgents

func PopulateInstancesAgents(instances [](*Instance)) error

PopulateInstancesAgents will fill in extra data acquired from agents for given instances At current this is the number of snapshots. This isn't too pretty; it's a push-into-instance-data-that-belongs-to-agent thing. Originally the need was to visually present the number of snapshots per host on the web/cluster page, which indeed proves to be useful in our experience.

func ReadClusterAliases

func ReadClusterAliases() error

ReadClusterAliases reads the entrie cluster name aliases mapping

func ReadClusterByAlias

func ReadClusterByAlias(alias string) (string, error)

ReadClusterAliases reads the entrie cluster name aliases mapping

func ReadClusterNameByMaster

func ReadClusterNameByMaster(instanceKey *InstanceKey, masterKey *InstanceKey) (clusterName string, replicationDepth uint, isCoMaster bool, err error)

ReadClusterNameByMaster will return the cluster name for a given instance by looking at its master and getting it from there. It is a non-recursive function and so-called-recursion is performed upon periodic reading of instances.

func ReadClusters

func ReadClusters() ([]string, error)

ReadClusters reads names of all known clusters

func ReadCountMySQLSnapshots

func ReadCountMySQLSnapshots(hostnames []string) (map[string]int, error)

ReadCountMySQLSnapshots is a utility method to return registered number of snapshots for a given list of hosts

func ReadResolvedHostname

func ReadResolvedHostname(hostname string) (string, error)

ReadResolvedHostname returns the resolved hostname given a hostname, or empty if not exists

func RefreshTopologyInstances

func RefreshTopologyInstances(instances [](*Instance))

RefreshTopologyInstances will do a blocking (though concurrent) refresh of all given instances

func RegisterCandidateInstance

func RegisterCandidateInstance(instanceKey *InstanceKey) error

RegisterCandidateInstance markes a given instance as suggested for successoring a master in the event of failover.

func RegisterHostnameUnresolve

func RegisterHostnameUnresolve(instanceKey *InstanceKey, unresolvedHostname string) error

RegisterHostnameUnresolve upserts an entry in hostname_unresolve

func RegroupSlaves

func RegroupSlaves(masterKey *InstanceKey, onCandidateSlaveChosen func(*Instance)) ([](*Instance), [](*Instance), [](*Instance), *Instance, error)

RegroupSlaves will choose a candidate slave of a given instance, and enslave its siblings using either simple CHANGE MASTER TO, where possible, or pseudo-gtid

func RematchSlave

func RematchSlave(instanceKey *InstanceKey, requireInstanceMaintenance bool, requireOtherMaintenance bool) (*Instance, *BinlogCoordinates, error)

RematchSlave will re-match a slave to its master, using pseudo-gtid

func ResetHostnameResolveCache

func ResetHostnameResolveCache() error

func ResolveHostname

func ResolveHostname(hostname string) (string, error)

Attempt to resolve a hostname. This may returned a database cached hostname or otherwise it may resolve the hostname via CNAME

func ReviewUnseenInstances

func ReviewUnseenInstances() error

ReviewUnseenInstances reviews instances that have not been seen (suposedly dead) and updates some of their data

func ScanInstanceRow

func ScanInstanceRow(instanceKey *InstanceKey, query string, dest ...interface{}) error

ScanInstanceRow executes a read-a-single-row query on a given MySQL topology instance

func SetClusterAlias

func SetClusterAlias(clusterName string, alias string) error

SetClusterAlias will write (and override) a single cluster name mapping

func SetMaintenanceOwner

func SetMaintenanceOwner(owner string)

func SnapshotTopologies

func SnapshotTopologies() error

SnapshotTopologies records topology graph for all existing topologies

func StartSlaves

func StartSlaves(slaves [](*Instance))

StartSlaves will do concurrent start-slave

func UpdateInstanceLastAttemptedCheck

func UpdateInstanceLastAttemptedCheck(instanceKey *InstanceKey) error

UpdateInstanceLastAttemptedCheck updates the last_attempted_check timestamp in the orchestrator backed database for a given instance. This is used as a failsafe mechanism in case access to the instance gets hung (it happens), in which case the entire ReadTopology gets stuck (and no, connection timeout nor driver timeouts don't help. Don't look at me, the world is a harsh place to live in). And so we make sure to note down *before* we even attempt to access the instance; and this raises a red flag when we wish to access the instance again: if last_attempted_check is *newer* than last_checked, that's bad news and means we have a "hanging" issue.

func UpdateInstanceLastChecked

func UpdateInstanceLastChecked(instanceKey *InstanceKey) error

UpdateInstanceLastChecked updates the last_check timestamp in the orchestrator backed database for a given instance

func UpdateResolvedHostname

func UpdateResolvedHostname(hostname string, resolvedHostname string) bool

UpdateResolvedHostname will store the given resolved hostname in cache Returns false when the key already existed with same resolved value (similar to AFFECTED_ROWS() in mysql)

func WriteClusterAlias

func WriteClusterAlias(clusterName string, alias string) error

WriteClusterAlias will write (and override) a single cluster name mapping

func WriteLongRunningProcesses

func WriteLongRunningProcesses(instanceKey *InstanceKey, processes []Process) error

WriteLongRunningProcesses rewrites current state of long running processes for given instance

func WriteResolvedHostname

func WriteResolvedHostname(hostname string, resolvedHostname string) error

WriteResolvedHostname stores a hostname and the resolved hostname to backend database

Types

type AnalysisCode

type AnalysisCode string

type Audit

type Audit struct {
	AuditId          int64
	AuditTimestamp   string
	AuditType        string
	AuditInstanceKey InstanceKey
	Message          string
}

Audit presents a single audit entry (namely in the database)

func ReadRecentAudit

func ReadRecentAudit(page int) ([]Audit, error)

ReadRecentAudit returns a list of audit entries order chronologically descending, using page number.

type BinlogCoordinates

type BinlogCoordinates struct {
	LogFile string
	LogPos  int64
	Type    BinlogType
}

BinlogCoordinates described binary log coordinates in the form of log file & log position.

func FindLastPseudoGTIDEntry

func FindLastPseudoGTIDEntry(instance *Instance, recordedInstanceRelayLogCoordinates BinlogCoordinates, exhaustiveSearch bool, expectedBinlogFormat *string) (*BinlogCoordinates, string, error)

FindLastPseudoGTIDEntry will search an instance's binary logs or relay logs for the last pseudo-GTID entry, and return found coordinates as well as entry text

func GetNextBinlogCoordinatesToMatch

func GetNextBinlogCoordinatesToMatch(instance *Instance, instanceCoordinates BinlogCoordinates, recordedInstanceRelayLogCoordinates BinlogCoordinates,
	other *Instance, otherCoordinates BinlogCoordinates) (*BinlogCoordinates, int, error)

GetNextBinlogCoordinatesToMatch is given a twin-coordinates couple for a would-be slave (instanceKey) and another instance (otherKey). This is part of the match-below process, and is the heart of the operation: matching the binlog events starting the twin-coordinates (where both share the same Pseudo-GTID) until "instance" runs out of entries, hopefully before "other" runs out. If "other" runs out that means "instance" is more advanced in replication than "other", in which case we can't turn it into a slave of "other". Otherwise "instance" will point to the *next* binlog entry in "other"

func SearchPseudoGTIDEntryInBinlog

func SearchPseudoGTIDEntryInBinlog(instanceKey *InstanceKey, binlog string, entryText string) (BinlogCoordinates, bool, error)

Given a binlog entry text (query), search it in the given binary log of a given instance

func SearchPseudoGTIDEntryInInstance

func SearchPseudoGTIDEntryInInstance(instance *Instance, entryText string) (*BinlogCoordinates, error)

SearchPseudoGTIDEntryInInstance will search for a specific text entry within the binary logs of a given instance.

func (*BinlogCoordinates) DisplayString

func (this *BinlogCoordinates) DisplayString() string

DisplayString returns a user-friendly string representation of these coordinates

func (*BinlogCoordinates) Equals

func (this *BinlogCoordinates) Equals(other *BinlogCoordinates) bool

Equals tests equality of this corrdinate and another one.

func (*BinlogCoordinates) FileSmallerThan

func (this *BinlogCoordinates) FileSmallerThan(other *BinlogCoordinates) bool

SmallerThan returns true if this coordinate is strictly smaller than the other.

func (*BinlogCoordinates) NextFileCoordinates

func (this *BinlogCoordinates) NextFileCoordinates() (BinlogCoordinates, error)

PreviousFileCoordinates guesses the filename of the previous binlog/relaylog

func (*BinlogCoordinates) PreviousFileCoordinates

func (this *BinlogCoordinates) PreviousFileCoordinates() (BinlogCoordinates, error)

PreviousFileCoordinates guesses the filename of the previous binlog/relaylog

func (*BinlogCoordinates) SmallerThan

func (this *BinlogCoordinates) SmallerThan(other *BinlogCoordinates) bool

SmallerThan returns true if this coordinate is strictly smaller than the other.

type BinlogEvent

type BinlogEvent struct {
	Coordinates  BinlogCoordinates
	NextEventPos int64
	EventType    string
	Info         string
}

func (*BinlogEvent) NextBinlogCoordinates

func (this *BinlogEvent) NextBinlogCoordinates() BinlogCoordinates

func (*BinlogEvent) NormalizeInfo

func (this *BinlogEvent) NormalizeInfo()

type BinlogEventCursor

type BinlogEventCursor struct {
	// contains filtered or unexported fields
}

func NewBinlogEventCursor

func NewBinlogEventCursor(startCoordinates BinlogCoordinates, fetchNextEventsFunc func(BinlogCoordinates) ([]BinlogEvent, error)) BinlogEventCursor

fetchNextEventsFunc expected to return events starting at a given position, and automatically fetch those from next binary log when no more rows are found in current log. It is expected to return empty array with no error upon end of binlogs It is expected to return error upon error...

type BinlogType

type BinlogType int
const (
	BinaryLog BinlogType = iota
	RelayLog
)

type ClusterInfo

type ClusterInfo struct {
	ClusterName                            string
	ClusterAlias                           string // Human friendly alias
	CountInstances                         uint
	HeuristicLag                           int64
	HasAutomatedMasterRecovery             bool
	HasAutomatedIntermediateMasterRecovery bool
}

ClusterInfo makes for a cluster status/info summary

func ReadClusterInfo

func ReadClusterInfo(clusterName string) (*ClusterInfo, error)

ReadClusterInfo reads some info about a given cluster

func ReadClustersInfo

func ReadClustersInfo() ([]ClusterInfo, error)

ReadClustersInfo reads names of all known clusters and some aggregated info

func (*ClusterInfo) ReadRecoveryInfo

func (this *ClusterInfo) ReadRecoveryInfo()

ReadRecoveryInfo

type ClusterPoolInstance

type ClusterPoolInstance struct {
	ClusterName  string
	ClusterAlias string
	Pool         string
	Hostname     string
	Port         int
}

ClusterPoolInstance is an instance mapping a cluster, pool & instance

func ReadAllClusterPoolInstances

func ReadAllClusterPoolInstances() ([](*ClusterPoolInstance), error)

type HostnameResolve

type HostnameResolve struct {
	// contains filtered or unexported fields
}

type Instance

type Instance struct {
	Key                    InstanceKey
	Uptime                 uint
	ServerID               uint
	Version                string
	ReadOnly               bool
	Binlog_format          string
	LogBinEnabled          bool
	LogSlaveUpdatesEnabled bool
	SelfBinlogCoordinates  BinlogCoordinates
	MasterKey              InstanceKey
	Slave_SQL_Running      bool
	Slave_IO_Running       bool
	HasReplicationFilters  bool
	SupportsOracleGTID     bool
	UsingOracleGTID        bool
	UsingMariaDBGTID       bool
	UsingPseudoGTID        bool
	ReadBinlogCoordinates  BinlogCoordinates
	ExecBinlogCoordinates  BinlogCoordinates
	RelaylogCoordinates    BinlogCoordinates
	LastSQLError           string
	LastIOError            string
	SecondsBehindMaster    sql.NullInt64
	SQLDelay               uint

	SlaveLagSeconds     sql.NullInt64
	SlaveHosts          InstanceKeyMap
	ClusterName         string
	DataCenter          string
	PhysicalEnvironment string
	ReplicationDepth    uint
	IsCoMaster          bool

	IsLastCheckValid     bool
	IsUpToDate           bool
	IsRecentlyChecked    bool
	SecondsSinceLastSeen sql.NullInt64
	CountMySQLSnapshots  int

	IsCandidate        bool
	UnresolvedHostname string
}

Instance represents a database instance, including its current configuration & status. It presents important replication configuration and detailed replication status.

func ChangeMasterTo

func ChangeMasterTo(instanceKey *InstanceKey, masterKey *InstanceKey, masterBinlogCoordinates *BinlogCoordinates, skipUnresolve bool) (*Instance, error)

ChangeMasterTo changes the given instance's master according to given input.

func DetachSlave

func DetachSlave(instanceKey *InstanceKey) (*Instance, error)

DetachSlave detaches a slave from replication; forcibly corrupting the binlog coordinates (though in such way that is reversible)

func DetachSlaveOperation

func DetachSlaveOperation(instanceKey *InstanceKey) (*Instance, error)

DetachSlaveOperation will detach a slave from its master by forcibly corrupting its replication coordinates

func EnslaveMaster

func EnslaveMaster(instanceKey *InstanceKey) (*Instance, error)

EnslaveMaster will move an instance up the chain and cause its master to become its slave. It's almost a role change, just that other slaves of either 'instance' or its master are currently unaffected (they continue replicate without change) Note that the master must itself be a slave; however the grandparent does not necessarily have to be reachable and can in fact be dead.

func EnslaveSiblings

func EnslaveSiblings(instanceKey *InstanceKey) (*Instance, int, error)

EnslaveSiblings is a convenience method for turning sublings of a slave to be its subordinates. This uses normal connected replication (does not utilize Pseudo-GTID)

func FindInstances

func FindInstances(regexpPattern string) ([](*Instance), error)

FindInstances reads all instances whose name matches given pattern

func GetClusterOSCSlaves

func GetClusterOSCSlaves(clusterName string) ([](*Instance), error)

GetClusterOSCSlaves returns a heuristic list of slaves which are fit as controll slaves for an OSC operation. These would be intermediate masters

func GetInstanceMaster

func GetInstanceMaster(instance *Instance) (*Instance, error)

GetInstanceMaster synchronously reaches into the replication topology and retrieves master's data

func KillQuery

func KillQuery(instanceKey *InstanceKey, process int64) (*Instance, error)

KillQuery stops replication on a given instance

func MakeCoMaster

func MakeCoMaster(instanceKey *InstanceKey) (*Instance, error)

MakeCoMaster will attempt to make an instance co-master with its master, by making its master a slave of its own. This only works out if the master is not replicating; the master does not have a known master (it may have an unknown master).

func MakeLocalMaster

func MakeLocalMaster(instanceKey *InstanceKey) (*Instance, error)

MakeLocalMaster promotes a slave above its master, making it slave of its grandparent, while also enslaving its siblings. This serves as a convenience method to recover replication when a local master fails; the instance promoted is one of its slaves, which is most advanced among its siblings. This method utilizes Pseudo GTID

func MakeMaster

func MakeMaster(instanceKey *InstanceKey) (*Instance, error)

MakeMaster will take an instance, make all its siblings its slaves (via pseudo-GTID) and make it master (stop its replicaiton, make writeable).

func MasterPosWait

func MasterPosWait(instanceKey *InstanceKey, binlogCoordinates *BinlogCoordinates) (*Instance, error)

MasterPosWait issues a MASTER_POS_WAIT() an given instance according to given coordinates.

func MoveBelow

func MoveBelow(instanceKey, siblingKey *InstanceKey) (*Instance, error)

MoveBelow will attempt moving instance indicated by instanceKey below its supposed sibling indicated by sinblingKey. It will perform all safety and sanity checks and will tamper with this instance's replication as well as its sibling.

func MoveBelowViaGTID

func MoveBelowViaGTID(instance, otherInstance *Instance) (*Instance, error)

MoveBelowViaGTID will attempt moving instance indicated by instanceKey below another instance using either Oracle GTID or MaroaDB GTID.

func MoveUp

func MoveUp(instanceKey *InstanceKey) (*Instance, error)

MoveUp will attempt moving instance indicated by instanceKey up the topology hierarchy. It will perform all safety and sanity checks and will tamper with this instance's replication as well as its master.

func NewInstance

func NewInstance() *Instance

NewInstance creates a new, empty instance

func ReadClusterCandidateInstances

func ReadClusterCandidateInstances(clusterName string) ([](*Instance), error)

ReadClusterCandidateInstances reads cluster instances which are also marked as candidates

func ReadClusterInstances

func ReadClusterInstances(clusterName string) ([](*Instance), error)

ReadClusterInstances reads all instances of a given cluster

func ReadHistoryClusterInstances

func ReadHistoryClusterInstances(clusterName string, historyTimestampPattern string) ([](*Instance), error)

ReadHistoryClusterInstances reads (thin) instances from history

func ReadInstance

func ReadInstance(instanceKey *InstanceKey) (*Instance, bool, error)

ReadInstance reads an instance from the orchestrator backend database

func ReadProblemInstances

func ReadProblemInstances() ([](*Instance), error)

ReadProblemInstances reads all instances with problems

func ReadSlaveInstances

func ReadSlaveInstances(masterKey *InstanceKey) ([](*Instance), error)

ReadSlaveInstances reads slaves of a given master

func ReadTopologyInstance

func ReadTopologyInstance(instanceKey *InstanceKey) (*Instance, error)

ReadTopologyInstance connects to a topology MySQL instance and reads its configuration and replication status. It writes read info into orchestrator's backend.

func ReadUnseenInstances

func ReadUnseenInstances() ([](*Instance), error)

ReadUnseenInstances reads all instances which were not recently seen

func ReattachSlave

func ReattachSlave(instanceKey *InstanceKey) (*Instance, error)

ReattachSlave restores a detahced slave back into replication

func ReattachSlaveOperation

func ReattachSlaveOperation(instanceKey *InstanceKey) (*Instance, error)

ReattachSlaveOperation will detach a slave from its master by forcibly corrupting its replication coordinates

func RefreshInstanceSlaveHosts

func RefreshInstanceSlaveHosts(instanceKey *InstanceKey) (*Instance, error)

RefreshInstanceSlaveHosts is a workaround for a bug in MySQL where SHOW SLAVE HOSTS continues to present old, long disconnected slaves. It turns out issuing a couple FLUSH commands mitigates the problem.

func RefreshTopologyInstance

func RefreshTopologyInstance(instanceKey *InstanceKey) (*Instance, error)

RefreshTopologyInstance will synchronuously re-read topology instance

func Repoint

func Repoint(instanceKey *InstanceKey, masterKey *InstanceKey) (*Instance, error)

Repoint connects a slave to a master using its exact same executing coordinates. The given masterKey can be null, in which case the existing master is used. Two use cases: - masterKey is nil: use case is corrupted relay logs on slave - masterKey is not nil: using MaxScale and Binlog servers (coordinates remain the same)

func RepointSlaves

func RepointSlaves(instanceKey *InstanceKey, pattern string) ([](*Instance), error, []error)

RepointSlaves sequentially repoints all slaves of a given instance onto its existing master.

func ResetSlave

func ResetSlave(instanceKey *InstanceKey) (*Instance, error)

ResetSlave resets a slave, breaking the replication

func ResetSlaveOperation

func ResetSlaveOperation(instanceKey *InstanceKey) (*Instance, error)

ResetSlaveOperation will reset a slave

func SearchInstances

func SearchInstances(searchString string) ([](*Instance), error)

SearchInstances reads all instances qualifying for some searchString

func SetReadOnly

func SetReadOnly(instanceKey *InstanceKey, readOnly bool) (*Instance, error)

SetReadOnly sets or clears the instance's global read_only variable

func SkipQuery

func SkipQuery(instanceKey *InstanceKey) (*Instance, error)

SkipQuery skip a single query in a failed replication instance

func StartSlave

func StartSlave(instanceKey *InstanceKey) (*Instance, error)

StartSlave starts replication on a given instance

func StartSlaveUntilMasterCoordinates

func StartSlaveUntilMasterCoordinates(instanceKey *InstanceKey, masterCoordinates *BinlogCoordinates) (*Instance, error)

StartSlaveUntilMasterCoordinates issuesa START SLAVE UNTIL... statement on given instance

func StopSlave

func StopSlave(instanceKey *InstanceKey) (*Instance, error)

StopSlave stops replication on a given instance

func StopSlaveNicely

func StopSlaveNicely(instanceKey *InstanceKey, timeout time.Duration) (*Instance, error)

StopSlaveNicely stops a slave such that SQL_thread and IO_thread are aligned (i.e. SQL_thread consumes all relay log entries) It will actually START the sql_thread even if the slave is completely stopped.

func StopSlavesNicely

func StopSlavesNicely(slaves [](*Instance), timeout time.Duration) [](*Instance)

StopSlavesNicely will attemt to stop all given slaves nicely, up to timeout

func (*Instance) AddSlaveKey

func (this *Instance) AddSlaveKey(slaveKey *InstanceKey)

AddSlaveKey adds a slave to the list of this instance's slaves.

func (*Instance) CanMove

func (this *Instance) CanMove() (bool, error)

CanMove returns true if this instance's state allows it to be repositioned. For example, if this instance lags too much, it will not be moveable.

func (*Instance) CanMoveAsCoMaster

func (this *Instance) CanMoveAsCoMaster() (bool, error)

CanMoveAsCoMaster returns true if this instance's state allows it to be repositioned.

func (*Instance) CanMoveViaMatch

func (this *Instance) CanMoveViaMatch() (bool, error)

CanMoveViaMatch returns true if this instance's state allows it to be repositioned via pseudo-GTID matching

func (*Instance) CanReplicateFrom

func (this *Instance) CanReplicateFrom(other *Instance) (bool, error)

CanReplicateFrom uses heursitics to decide whether this instacne can practically replicate from other instance. Checks are made to binlog format, version number, binary logs etc.

func (*Instance) Equals

func (this *Instance) Equals(other *Instance) bool

Equals tests that this instance is the same instance as other. The function does not test configuration or status.

func (*Instance) GetNextBinaryLog

func (this *Instance) GetNextBinaryLog(binlogCoordinates BinlogCoordinates) (BinlogCoordinates, error)

GetNextBinaryLog returns the successive, if any, binary log file to the one given

func (*Instance) GetSlaveHostsAsJson

func (this *Instance) GetSlaveHostsAsJson() string

GetSlaveHostsAsJson Marshals slaves list a JSON

func (*Instance) HasReasonableMaintenanceReplicationLag

func (this *Instance) HasReasonableMaintenanceReplicationLag() bool

HasReasonableMaintenanceReplicationLag returns true when the slave lag is reasonable, and maintenance operations should have a green light to go.

func (*Instance) HumanReadableDescription

func (this *Instance) HumanReadableDescription() string

HumanReadableDescription returns a simple readable string describing the status, version, etc. properties of this instance

func (*Instance) IsMariaDB

func (this *Instance) IsMariaDB() bool

IsMariaDB checkes whether this is any version of MariaDB

func (*Instance) IsMasterOf

func (this *Instance) IsMasterOf(slave *Instance) bool

IsSlaveOf returns true if this i supposed master of given slave

func (*Instance) IsMaxScale

func (this *Instance) IsMaxScale() bool

IsMariaDB checkes whether this is any version of MaScale

func (*Instance) IsSlave

func (this *Instance) IsSlave() bool

IsSlave makes simple heuristics to decide whether this insatnce is a slave of another instance

func (*Instance) IsSlaveOf

func (this *Instance) IsSlaveOf(master *Instance) bool

IsSlaveOf returns true if this instance claims to replicate from given master

func (*Instance) IsSmallerMajorVersion

func (this *Instance) IsSmallerMajorVersion(other *Instance) bool

MajorVersion tests this instance against another and returns true if this instance is of a smaller "major" varsion. e.g. 5.5.36 is NOT a smaller major version as comapred to 5.5.36, but IS as compared to 5.6.9

func (*Instance) MajorVersion

func (this *Instance) MajorVersion() []string

MajorVersion returns this instance's major version number (e.g. for 5.5.36 it returns "5.5")

func (*Instance) ReadSlaveHostsFromJson

func (this *Instance) ReadSlaveHostsFromJson(jsonString string) error

ReadSlaveHostsFromJson unmarshalls a json to read list of slaves

func (*Instance) SQLThreadUpToDate

func (this *Instance) SQLThreadUpToDate() bool

SQLThreadUpToDate returns true when the instance had consumed all relay logs.

func (*Instance) SlaveRunning

func (this *Instance) SlaveRunning() bool

SlaveRunning returns true when this instance's status is of a replicating slave.

func (*Instance) StatusString

func (this *Instance) StatusString() string

StatusString returns a human readable description of this instance's status

func (*Instance) UsingGTID

func (this *Instance) UsingGTID() bool

UsingGTID returns true when this slave is currently replicating via GTID (either Oracle or MariaDB)

type InstanceKey

type InstanceKey struct {
	Hostname string
	Port     int
}

InstanceKey is an instance indicator, identifued by hostname and port

func NewInstanceKeyFromStrings

func NewInstanceKeyFromStrings(hostname string, port string) (*InstanceKey, error)

NewInstanceKeyFromStrings creates a new InstanceKey by resolving hostname and port. hostname is normalized via ResolveHostname. port is tested to be valid integer.

func NewRawInstanceKey

func NewRawInstanceKey(hostPort string) (*InstanceKey, error)

ParseInstanceKey will parse an InstanceKey from a string representation such as 127.0.0.1:3306

func ParseInstanceKey

func ParseInstanceKey(hostPort string) (*InstanceKey, error)

ParseInstanceKey will parse an InstanceKey from a string representation such as 127.0.0.1:3306

func ParseInstanceKeyLoose

func ParseInstanceKeyLoose(hostPort string) (*InstanceKey, error)

ParseInstanceKeyLoose will parse an InstanceKey from a string representation such as 127.0.0.1:3306. The port part is optional

func ReadMaintenanceInstanceKey

func ReadMaintenanceInstanceKey(maintenanceToken int64) (*InstanceKey, error)

ReadMaintenanceInstanceKey will return the instanceKey for active maintenance by maintenanceToken

func ReadOutdatedInstanceKeys

func ReadOutdatedInstanceKeys() ([]InstanceKey, error)

ReadOutdatedInstanceKeys reads and returns keys for all instances that are not up to date (i.e. pre-configured time has passed since they were last cheked) But we also check for the case where an attempt at instance checking has been made, that hasn't resulted in an actual check! This can happen when TCP/IP connections are hung, in which case the "check" never returns. In such case we multiply interval by a factor, so as not to open too many connections on the instance.

func UnresolveHostname

func UnresolveHostname(instanceKey *InstanceKey) (InstanceKey, bool, error)

func (*InstanceKey) DisplayString

func (this *InstanceKey) DisplayString() string

DisplayString returns a user-friendly string representation of this key

func (*InstanceKey) Equals

func (this *InstanceKey) Equals(other *InstanceKey) bool

Equals tests equality between this key and another key

func (*InstanceKey) Formalize

func (this *InstanceKey) Formalize() *InstanceKey

Formalize this key by getting CNAME for hostname

func (*InstanceKey) IsValid

func (this *InstanceKey) IsValid() bool

IsValid uses simple heuristics to see whether this key represents an actual instance

type InstanceKeyMap

type InstanceKeyMap map[InstanceKey]bool

InstanceKeyMap is a convenience struct for listing InstanceKey-s

func (*InstanceKeyMap) GetInstanceKeys

func (this *InstanceKeyMap) GetInstanceKeys() []InstanceKey

GetInstanceKeys returns keys in this map in the form of an array

func (*InstanceKeyMap) MarshalJSON

func (this *InstanceKeyMap) MarshalJSON() ([]byte, error)

MarshalJSON will marshal this map as JSON

type InstancesByCountSlaveHosts

type InstancesByCountSlaveHosts [](*Instance)

InstancesByCountSlaveHosts is a sortable type for Instance

func (InstancesByCountSlaveHosts) Len

func (this InstancesByCountSlaveHosts) Len() int

func (InstancesByCountSlaveHosts) Less

func (this InstancesByCountSlaveHosts) Less(i, j int) bool

func (InstancesByCountSlaveHosts) Swap

func (this InstancesByCountSlaveHosts) Swap(i, j int)

type InstancesByExecBinlogCoordinates

type InstancesByExecBinlogCoordinates [](*Instance)

InstancesByExecBinlogCoordinates is a sortabel type for BinlogCoordinates

func (InstancesByExecBinlogCoordinates) Len

func (InstancesByExecBinlogCoordinates) Less

func (this InstancesByExecBinlogCoordinates) Less(i, j int) bool

func (InstancesByExecBinlogCoordinates) Swap

func (this InstancesByExecBinlogCoordinates) Swap(i, j int)

type Maintenance

type Maintenance struct {
	MaintenanceId  uint
	Key            InstanceKey
	BeginTimestamp string
	SecondsElapsed uint
	IsActive       bool
	Owner          string
	Reason         string
}

Maintenance indicates a maintenance entry (also in the database)

func ReadActiveMaintenance

func ReadActiveMaintenance() ([]Maintenance, error)

ReadActiveMaintenance returns the list of currently active maintenance entries

type PoolInstancesMap

type PoolInstancesMap map[string]([]*InstanceKey)

PoolInstancesMap lists instance keys per pool name

func ReadClusterPoolInstances

func ReadClusterPoolInstances(clusterName string) (*PoolInstancesMap, error)

type Process

type Process struct {
	InstanceHostname string
	InstancePort     int
	Id               int64
	User             string
	Host             string
	Db               string
	Command          string
	Time             int64
	State            string
	Info             string
	StartedAt        string
}

Process presents a MySQL executing thread (as observed by PROCESSLIST)

func ReadLongRunningProcesses

func ReadLongRunningProcesses(filter string) ([]Process, error)

ReadLongRunningProcesses returns the list of current known long running processes of all instances

type ReplicationAnalysis

type ReplicationAnalysis struct {
	AnalyzedInstanceKey         InstanceKey
	AnalyzedInstanceMasterKey   InstanceKey
	ClusterDetails              ClusterInfo
	IsMaster                    bool
	IsCoMaster                  bool
	LastCheckValid              bool
	CountSlaves                 uint
	CountValidSlaves            uint
	CountValidReplicatingSlaves uint
	ReplicationDepth            uint
	SlaveHosts                  InstanceKeyMap
	IsFailingToConnectToMaster  bool
	Analysis                    AnalysisCode
	Description                 string
	IsDowntimed                 bool
	DowntimeEndTimestamp        string
	DowntimeRemainingSeconds    int
	IsMaxscale                  bool
}

ReplicationAnalysis notes analysis on replication chain status, per instance

func GetReplicationAnalysis

func GetReplicationAnalysis(includeDowntimed bool) ([]ReplicationAnalysis, error)

GetReplicationAnalysis will check for replication problems (dead master; unreachable master; etc)

func (*ReplicationAnalysis) GetSlaveHostsAsString

func (this *ReplicationAnalysis) GetSlaveHostsAsString() string

GetSlaveHostsAsString serializes all slave keys as a single comma delimited string

func (*ReplicationAnalysis) ReadSlaveHostsFromString

func (this *ReplicationAnalysis) ReadSlaveHostsFromString(slaveHostsString string) error

ReadSlaveHostsFromString parses and reads slave keys from comma delimited string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL