2016-02-20 01:32:16 +00:00
|
|
|
package server_manager
|
|
|
|
|
|
|
|
import (
|
|
|
|
"log"
|
|
|
|
"math/rand"
|
|
|
|
"sync"
|
|
|
|
"sync/atomic"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/hashicorp/consul/consul/server_details"
|
|
|
|
"github.com/hashicorp/consul/lib"
|
|
|
|
)
|
|
|
|
|
|
|
|
type consulServerEventTypes int
|
|
|
|
|
|
|
|
const (
|
|
|
|
// clientRPCJitterFraction determines the amount of jitter added to
|
|
|
|
// clientRPCMinReuseDuration before a connection is expired and a new
|
|
|
|
// connection is established in order to rebalance load across consul
|
|
|
|
// servers. The cluster-wide number of connections per second from
|
|
|
|
// rebalancing is applied after this jitter to ensure the CPU impact
|
|
|
|
// is always finite. See newRebalanceConnsPerSecPerServer's comment
|
|
|
|
// for additional commentary.
|
|
|
|
//
|
|
|
|
// For example, in a 10K consul cluster with 5x servers, this default
|
|
|
|
// averages out to ~13 new connections from rebalancing per server
|
|
|
|
// per second (each connection is reused for 120s to 180s).
|
|
|
|
clientRPCJitterFraction = 2
|
|
|
|
|
|
|
|
// clientRPCMinReuseDuration controls the minimum amount of time RPC
|
|
|
|
// queries are sent over an established connection to a single server
|
|
|
|
clientRPCMinReuseDuration = 120 * time.Second
|
|
|
|
|
|
|
|
// Limit the number of new connections a server receives per second
|
|
|
|
// for connection rebalancing. This limit caps the load caused by
|
|
|
|
// continual rebalancing efforts when a cluster is in equilibrium. A
|
|
|
|
// lower value comes at the cost of increased recovery time after a
|
|
|
|
// partition. This parameter begins to take effect when there are
|
|
|
|
// more than ~48K clients querying 5x servers or at lower server
|
|
|
|
// values when there is a partition.
|
|
|
|
//
|
|
|
|
// For example, in a 100K consul cluster with 5x servers, it will
|
|
|
|
// take ~5min for all servers to rebalance their connections. If
|
|
|
|
// 99,995 agents are in the minority talking to only one server, it
|
|
|
|
// will take ~26min for all servers to rebalance. A 10K cluster in
|
|
|
|
// the same scenario will take ~2.6min to rebalance.
|
|
|
|
newRebalanceConnsPerSecPerServer = 64
|
|
|
|
)
|
|
|
|
|
2016-02-24 23:04:04 +00:00
|
|
|
type ConsulClusterInfo interface {
|
|
|
|
NumNodes() int
|
|
|
|
}
|
|
|
|
|
2016-03-25 19:34:46 +00:00
|
|
|
// serverCfg is the thread-safe configuration struct used to maintain the
|
|
|
|
// list of Consul servers in ServerManager.
|
2016-02-20 01:32:16 +00:00
|
|
|
//
|
2016-02-25 03:51:56 +00:00
|
|
|
// NOTE(sean@): We are explicitly relying on the fact that serverConfig will
|
|
|
|
// be copied onto the stack. Please keep this structure light.
|
2016-02-20 01:32:16 +00:00
|
|
|
type serverConfig struct {
|
2016-02-25 03:51:56 +00:00
|
|
|
// servers tracks the locally known servers. List membership is
|
|
|
|
// maintained by Serf.
|
2016-02-20 01:32:16 +00:00
|
|
|
servers []*server_details.ServerDetails
|
|
|
|
}
|
|
|
|
|
|
|
|
type ServerManager struct {
|
2016-02-25 03:51:56 +00:00
|
|
|
// serverConfig provides the necessary load/store semantics for the
|
|
|
|
// server list.
|
2016-02-20 01:32:16 +00:00
|
|
|
serverConfigValue atomic.Value
|
|
|
|
serverConfigLock sync.Mutex
|
|
|
|
|
|
|
|
// shutdownCh is a copy of the channel in consul.Client
|
|
|
|
shutdownCh chan struct{}
|
|
|
|
|
|
|
|
logger *log.Logger
|
2016-02-24 18:55:04 +00:00
|
|
|
|
2016-03-25 19:38:40 +00:00
|
|
|
// clusterInfo is used to estimate the approximate number of nodes in
|
|
|
|
// a cluster and limit the rate at which it rebalances server
|
|
|
|
// connections. ConsulClusterInfo is an interface that wraps serf.
|
2016-02-24 23:04:04 +00:00
|
|
|
clusterInfo ConsulClusterInfo
|
2016-02-25 03:11:16 +00:00
|
|
|
|
|
|
|
// notifyFailedServersBarrier is acts as a barrier to prevent
|
|
|
|
// queueing behind serverConfigLog and acts as a TryLock().
|
|
|
|
notifyFailedBarrier int32
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-20 02:57:15 +00:00
|
|
|
// AddServer takes out an internal write lock and adds a new server. If the
|
2016-02-25 03:51:56 +00:00
|
|
|
// server is not known, appends the server to the list. The new server will
|
|
|
|
// begin seeing use after the rebalance timer fires or enough servers fail
|
|
|
|
// organically. If the server is already known, merge the new server
|
|
|
|
// details.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sm *ServerManager) AddServer(server *server_details.ServerDetails) {
|
|
|
|
sm.serverConfigLock.Lock()
|
|
|
|
defer sm.serverConfigLock.Unlock()
|
2016-02-20 02:56:15 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
2016-02-20 01:32:16 +00:00
|
|
|
|
|
|
|
// Check if this server is known
|
|
|
|
found := false
|
|
|
|
for idx, existing := range serverCfg.servers {
|
|
|
|
if existing.Name == server.Name {
|
2016-02-20 03:01:46 +00:00
|
|
|
newServers := make([]*server_details.ServerDetails, len(serverCfg.servers))
|
|
|
|
copy(newServers, serverCfg.servers)
|
|
|
|
|
|
|
|
// Overwrite the existing server details in order to
|
|
|
|
// possibly update metadata (e.g. server version)
|
|
|
|
newServers[idx] = server
|
|
|
|
|
|
|
|
serverCfg.servers = newServers
|
2016-02-20 01:32:16 +00:00
|
|
|
found = true
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add to the list if not known
|
|
|
|
if !found {
|
2016-02-22 21:01:44 +00:00
|
|
|
newServers := make([]*server_details.ServerDetails, len(serverCfg.servers), len(serverCfg.servers)+1)
|
2016-02-20 01:32:16 +00:00
|
|
|
copy(newServers, serverCfg.servers)
|
2016-02-22 21:01:44 +00:00
|
|
|
newServers = append(newServers, server)
|
2016-02-20 01:32:16 +00:00
|
|
|
serverCfg.servers = newServers
|
|
|
|
}
|
|
|
|
|
2016-02-22 21:11:07 +00:00
|
|
|
sm.saveServerConfig(serverCfg)
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-20 02:57:15 +00:00
|
|
|
// cycleServers returns a new list of servers that has dequeued the first
|
|
|
|
// server and enqueued it at the end of the list. cycleServers assumes the
|
|
|
|
// caller is holding the serverConfigLock.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sc *serverConfig) cycleServer() (servers []*server_details.ServerDetails) {
|
2016-02-22 21:01:44 +00:00
|
|
|
numServers := len(sc.servers)
|
2016-02-20 01:32:16 +00:00
|
|
|
if numServers < 2 {
|
2016-02-25 03:51:56 +00:00
|
|
|
return servers // No action required
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-22 21:01:44 +00:00
|
|
|
newServers := make([]*server_details.ServerDetails, 0, numServers)
|
|
|
|
newServers = append(newServers, sc.servers[1:]...)
|
|
|
|
newServers = append(newServers, sc.servers[0])
|
|
|
|
return newServers
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-25 06:05:05 +00:00
|
|
|
// FindServer takes out an internal "read lock" and searches through the list
|
|
|
|
// of servers to find a "healthy" server. If the server is actually
|
2016-02-25 03:51:56 +00:00
|
|
|
// unhealthy, we rely on Serf to detect this and remove the node from the
|
|
|
|
// server list. If the server at the front of the list has failed or fails
|
|
|
|
// during an RPC call, it is rotated to the end of the list. If there are no
|
|
|
|
// servers available, return nil.
|
2016-02-25 06:05:05 +00:00
|
|
|
func (sm *ServerManager) FindServer() *server_details.ServerDetails {
|
2016-02-20 01:32:16 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
|
|
|
numServers := len(serverCfg.servers)
|
|
|
|
if numServers == 0 {
|
2016-02-25 06:23:50 +00:00
|
|
|
sm.logger.Printf("[WARN] consul: No servers found in the server config")
|
2016-02-20 01:32:16 +00:00
|
|
|
return nil
|
2016-02-24 22:48:04 +00:00
|
|
|
} else {
|
2016-02-25 03:51:56 +00:00
|
|
|
// Return whatever is at the front of the list because it is
|
|
|
|
// assumed to be the oldest in the server list (unless -
|
|
|
|
// hypothetically - the server list was rotated right after a
|
|
|
|
// server was added).
|
2016-02-24 22:48:04 +00:00
|
|
|
return serverCfg.servers[0]
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-02-22 21:01:44 +00:00
|
|
|
// getServerConfig is a convenience method which hides the locking semantics
|
|
|
|
// of atomic.Value from the caller.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sm *ServerManager) getServerConfig() serverConfig {
|
|
|
|
return sm.serverConfigValue.Load().(serverConfig)
|
|
|
|
}
|
|
|
|
|
2016-03-25 19:41:22 +00:00
|
|
|
// saveServerConfig is a convenience method which hides the locking semantics
|
|
|
|
// of atomic.Value from the caller.
|
|
|
|
func (sm *ServerManager) saveServerConfig(sc serverConfig) {
|
|
|
|
sm.serverConfigValue.Store(sc)
|
|
|
|
}
|
|
|
|
|
2016-02-25 06:08:13 +00:00
|
|
|
// New is the only way to safely create a new ServerManager struct.
|
|
|
|
func New(logger *log.Logger, shutdownCh chan struct{}, clusterInfo ConsulClusterInfo) (sm *ServerManager) {
|
2016-02-22 21:01:44 +00:00
|
|
|
// NOTE(sean@): Can't pass *consul.Client due to an import cycle
|
2016-02-20 01:32:16 +00:00
|
|
|
sm = new(ServerManager)
|
|
|
|
sm.logger = logger
|
2016-02-25 03:51:56 +00:00
|
|
|
sm.clusterInfo = clusterInfo
|
2016-02-20 01:32:16 +00:00
|
|
|
sm.shutdownCh = shutdownCh
|
2016-02-22 21:01:44 +00:00
|
|
|
|
|
|
|
sc := serverConfig{}
|
|
|
|
sc.servers = make([]*server_details.ServerDetails, 0)
|
2016-02-25 03:51:56 +00:00
|
|
|
sm.saveServerConfig(sc)
|
2016-02-20 01:32:16 +00:00
|
|
|
return sm
|
|
|
|
}
|
|
|
|
|
2016-02-25 03:51:56 +00:00
|
|
|
// NotifyFailedServer marks the passed in server as "failed" by rotating it
|
|
|
|
// to the end of the server list.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sm *ServerManager) NotifyFailedServer(server *server_details.ServerDetails) {
|
2016-02-24 22:48:04 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
|
|
|
|
2016-02-25 03:51:56 +00:00
|
|
|
// If the server being failed is not the first server on the list,
|
|
|
|
// this is a noop. If, however, the server is failed and first on
|
|
|
|
// the list, acquire the lock, retest, and take the penalty of moving
|
|
|
|
// the server to the end of the list.
|
|
|
|
|
2016-03-25 19:54:36 +00:00
|
|
|
// Only rotate the server list when there is more than one server
|
|
|
|
if len(serverCfg.servers) > 1 && serverCfg.servers[0] == server &&
|
|
|
|
// Use atomic.CAS to emulate a TryLock().
|
2016-02-25 03:11:16 +00:00
|
|
|
atomic.CompareAndSwapInt32(&sm.notifyFailedBarrier, 0, 1) {
|
|
|
|
defer atomic.StoreInt32(&sm.notifyFailedBarrier, 0)
|
|
|
|
|
2016-02-24 22:48:04 +00:00
|
|
|
// Grab a lock, retest, and take the hit of cycling the first
|
|
|
|
// server to the end.
|
2016-02-25 03:11:16 +00:00
|
|
|
sm.serverConfigLock.Lock()
|
2016-02-24 22:48:04 +00:00
|
|
|
defer sm.serverConfigLock.Unlock()
|
|
|
|
serverCfg = sm.getServerConfig()
|
|
|
|
|
2016-03-25 19:54:36 +00:00
|
|
|
if len(serverCfg.servers) > 1 && serverCfg.servers[0] == server {
|
2016-02-25 04:25:50 +00:00
|
|
|
serverCfg.servers = serverCfg.cycleServer()
|
2016-02-24 22:48:04 +00:00
|
|
|
sm.saveServerConfig(serverCfg)
|
|
|
|
}
|
|
|
|
}
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-25 06:09:49 +00:00
|
|
|
// NumServers takes out an internal "read lock" and returns the number of
|
|
|
|
// servers. numServers includes both healthy and unhealthy servers.
|
|
|
|
func (sm *ServerManager) NumServers() (numServers int) {
|
|
|
|
serverCfg := sm.getServerConfig()
|
|
|
|
numServers = len(serverCfg.servers)
|
|
|
|
return numServers
|
|
|
|
}
|
|
|
|
|
2016-02-20 02:57:15 +00:00
|
|
|
// RebalanceServers takes out an internal write lock and shuffles the list of
|
|
|
|
// servers on this agent. This allows for a redistribution of work across
|
2016-02-25 03:51:56 +00:00
|
|
|
// consul servers and provides a guarantee that the order of the server list
|
|
|
|
// isn't related to the age at which the node was added to the cluster.
|
|
|
|
// Elsewhere we rely on the position in the server list as a hint regarding
|
|
|
|
// the stability of a server relative to its position in the server list.
|
|
|
|
// Servers at or near the front of the list are more stable than servers near
|
2016-03-25 20:06:59 +00:00
|
|
|
// the end of the list. Unhealthy servers are removed when serf notices the
|
|
|
|
// server has been deregistered.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sm *ServerManager) RebalanceServers() {
|
|
|
|
sm.serverConfigLock.Lock()
|
|
|
|
defer sm.serverConfigLock.Unlock()
|
2016-02-20 02:56:15 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
2016-02-20 01:32:16 +00:00
|
|
|
|
2016-02-22 21:01:44 +00:00
|
|
|
newServers := make([]*server_details.ServerDetails, len(serverCfg.servers))
|
2016-02-20 03:01:46 +00:00
|
|
|
copy(newServers, serverCfg.servers)
|
|
|
|
|
2016-03-25 20:06:59 +00:00
|
|
|
// Shuffle the server list
|
2016-02-20 01:32:16 +00:00
|
|
|
for i := len(serverCfg.servers) - 1; i > 0; i-- {
|
|
|
|
j := rand.Int31n(int32(i + 1))
|
2016-02-20 03:01:46 +00:00
|
|
|
newServers[i], newServers[j] = newServers[j], newServers[i]
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
2016-02-20 03:01:46 +00:00
|
|
|
serverCfg.servers = newServers
|
2016-02-20 01:32:16 +00:00
|
|
|
|
2016-02-22 21:11:07 +00:00
|
|
|
sm.saveServerConfig(serverCfg)
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
2016-02-20 02:57:15 +00:00
|
|
|
// RemoveServer takes out an internal write lock and removes a server from
|
2016-02-25 03:51:56 +00:00
|
|
|
// the server list.
|
2016-02-20 01:32:16 +00:00
|
|
|
func (sm *ServerManager) RemoveServer(server *server_details.ServerDetails) {
|
|
|
|
sm.serverConfigLock.Lock()
|
|
|
|
defer sm.serverConfigLock.Unlock()
|
2016-02-20 02:56:15 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
2016-02-20 01:32:16 +00:00
|
|
|
|
|
|
|
// Remove the server if known
|
2016-03-25 20:08:08 +00:00
|
|
|
for i, _ := range serverCfg.servers {
|
2016-02-20 01:32:16 +00:00
|
|
|
if serverCfg.servers[i].Name == server.Name {
|
2016-02-25 06:23:50 +00:00
|
|
|
newServers := make([]*server_details.ServerDetails, 0, len(serverCfg.servers)-1)
|
|
|
|
newServers = append(newServers, serverCfg.servers[:i]...)
|
|
|
|
newServers = append(newServers, serverCfg.servers[i+1:]...)
|
2016-02-20 03:01:46 +00:00
|
|
|
serverCfg.servers = newServers
|
|
|
|
|
2016-02-22 21:11:07 +00:00
|
|
|
sm.saveServerConfig(serverCfg)
|
2016-02-20 03:01:46 +00:00
|
|
|
return
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-02-25 03:51:56 +00:00
|
|
|
// refreshServerRebalanceTimer is only called once the rebalanceTimer
|
|
|
|
// expires. Historically this was an expensive routine and is intended to be
|
|
|
|
// run in isolation in a dedicated, non-concurrent task.
|
2016-02-25 16:05:15 +00:00
|
|
|
func (sm *ServerManager) refreshServerRebalanceTimer(timer *time.Timer) time.Duration {
|
2016-02-24 18:55:04 +00:00
|
|
|
serverCfg := sm.getServerConfig()
|
|
|
|
numConsulServers := len(serverCfg.servers)
|
2016-02-20 01:32:16 +00:00
|
|
|
// Limit this connection's life based on the size (and health) of the
|
|
|
|
// cluster. Never rebalance a connection more frequently than
|
|
|
|
// connReuseLowWatermarkDuration, and make sure we never exceed
|
|
|
|
// clusterWideRebalanceConnsPerSec operations/s across numLANMembers.
|
|
|
|
clusterWideRebalanceConnsPerSec := float64(numConsulServers * newRebalanceConnsPerSecPerServer)
|
|
|
|
connReuseLowWatermarkDuration := clientRPCMinReuseDuration + lib.RandomStagger(clientRPCMinReuseDuration/clientRPCJitterFraction)
|
2016-02-24 23:04:04 +00:00
|
|
|
numLANMembers := sm.clusterInfo.NumNodes()
|
2016-02-20 01:32:16 +00:00
|
|
|
connRebalanceTimeout := lib.RateScaledInterval(clusterWideRebalanceConnsPerSec, connReuseLowWatermarkDuration, numLANMembers)
|
|
|
|
|
2016-02-24 18:55:04 +00:00
|
|
|
timer.Reset(connRebalanceTimeout)
|
2016-02-25 16:05:15 +00:00
|
|
|
return connRebalanceTimeout
|
2016-02-24 18:55:04 +00:00
|
|
|
}
|
|
|
|
|
2016-02-24 22:48:04 +00:00
|
|
|
// Start is used to start and manage the task of automatically shuffling and
|
2016-02-25 03:51:56 +00:00
|
|
|
// rebalancing the list of consul servers. This maintenance only happens
|
|
|
|
// periodically based on the expiration of the timer. Failed servers are
|
|
|
|
// automatically cycled to the end of the list. New servers are appended to
|
|
|
|
// the list. The order of the server list must be shuffled periodically to
|
|
|
|
// distribute load across all known and available consul servers.
|
2016-02-24 22:48:04 +00:00
|
|
|
func (sm *ServerManager) Start() {
|
2016-03-25 20:46:18 +00:00
|
|
|
var rebalanceTimer *time.Timer = time.NewTimer(clientRPCMinReuseDuration)
|
2016-02-24 18:55:04 +00:00
|
|
|
var rebalanceTaskDispatched int32
|
|
|
|
|
2016-02-20 01:32:16 +00:00
|
|
|
func() {
|
|
|
|
sm.serverConfigLock.Lock()
|
|
|
|
defer sm.serverConfigLock.Unlock()
|
|
|
|
|
|
|
|
serverCfgPtr := sm.serverConfigValue.Load()
|
|
|
|
if serverCfgPtr == nil {
|
|
|
|
panic("server config has not been initialized")
|
|
|
|
}
|
|
|
|
var serverCfg serverConfig
|
|
|
|
serverCfg = serverCfgPtr.(serverConfig)
|
2016-02-22 21:11:07 +00:00
|
|
|
sm.saveServerConfig(serverCfg)
|
2016-02-20 01:32:16 +00:00
|
|
|
}()
|
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
2016-02-24 22:48:04 +00:00
|
|
|
case <-rebalanceTimer.C:
|
|
|
|
sm.logger.Printf("[INFO] server manager: server rebalance timeout")
|
|
|
|
sm.RebalanceServers()
|
|
|
|
|
2016-02-24 18:55:04 +00:00
|
|
|
// Only run one rebalance task at a time, but do
|
|
|
|
// allow for the channel to be drained
|
|
|
|
if atomic.CompareAndSwapInt32(&rebalanceTaskDispatched, 0, 1) {
|
2016-02-24 22:48:04 +00:00
|
|
|
sm.logger.Printf("[INFO] server manager: Launching rebalance duration task")
|
2016-02-24 18:55:04 +00:00
|
|
|
go func() {
|
|
|
|
defer atomic.StoreInt32(&rebalanceTaskDispatched, 0)
|
|
|
|
sm.refreshServerRebalanceTimer(rebalanceTimer)
|
|
|
|
}()
|
2016-02-20 01:32:16 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
case <-sm.shutdownCh:
|
2016-02-24 22:48:04 +00:00
|
|
|
sm.logger.Printf("[INFO] server manager: shutting down")
|
2016-02-20 01:32:16 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|