redis/sentinel.go

497 lines
12 KiB
Go
Raw Normal View History

2014-05-11 18:11:55 +04:00
package redis
import (
"context"
"crypto/tls"
2014-05-11 18:11:55 +04:00
"errors"
"net"
"strings"
"sync"
"time"
2019-08-08 14:29:44 +03:00
"github.com/go-redis/redis/v7/internal"
"github.com/go-redis/redis/v7/internal/pool"
2014-05-11 18:11:55 +04:00
)
//------------------------------------------------------------------------------
// FailoverOptions are used to configure a failover client and should
// be passed to NewFailoverClient.
2014-05-11 18:11:55 +04:00
type FailoverOptions struct {
2015-01-31 17:54:37 +03:00
// The master name.
MasterName string
// A seed list of host:port addresses of sentinel nodes.
2019-06-04 14:05:29 +03:00
SentinelAddrs []string
SentinelPassword string
2014-05-11 18:11:55 +04:00
// Following options are copied from Options struct.
2019-06-04 14:05:29 +03:00
Dialer func(ctx context.Context, network, addr string) (net.Conn, error)
2017-05-25 14:16:39 +03:00
OnConnect func(*Conn) error
2019-06-04 14:05:29 +03:00
Password string
DB int
MaxRetries int
MinRetryBackoff time.Duration
MaxRetryBackoff time.Duration
2016-03-17 19:00:47 +03:00
DialTimeout time.Duration
ReadTimeout time.Duration
2015-01-31 17:54:37 +03:00
WriteTimeout time.Duration
2014-05-11 18:11:55 +04:00
2016-03-17 19:00:47 +03:00
PoolSize int
MinIdleConns int
MaxConnAge time.Duration
2016-03-17 19:00:47 +03:00
PoolTimeout time.Duration
IdleTimeout time.Duration
IdleCheckFrequency time.Duration
TLSConfig *tls.Config
2014-05-11 18:11:55 +04:00
}
func (opt *FailoverOptions) options() *Options {
return &Options{
2019-05-18 14:00:07 +03:00
Addr: "FailoverClient",
Dialer: opt.Dialer,
2017-05-25 14:16:39 +03:00
OnConnect: opt.OnConnect,
2014-05-11 18:11:55 +04:00
DB: opt.DB,
Password: opt.Password,
2016-03-17 19:00:47 +03:00
MaxRetries: opt.MaxRetries,
DialTimeout: opt.DialTimeout,
2014-05-11 18:11:55 +04:00
ReadTimeout: opt.ReadTimeout,
WriteTimeout: opt.WriteTimeout,
2016-03-17 19:00:47 +03:00
PoolSize: opt.PoolSize,
PoolTimeout: opt.PoolTimeout,
IdleTimeout: opt.IdleTimeout,
IdleCheckFrequency: opt.IdleCheckFrequency,
TLSConfig: opt.TLSConfig,
2014-05-11 18:11:55 +04:00
}
}
2015-09-12 09:36:03 +03:00
// NewFailoverClient returns a Redis client that uses Redis Sentinel
// for automatic failover. It's safe for concurrent use by multiple
// goroutines.
2014-05-11 18:11:55 +04:00
func NewFailoverClient(failoverOpt *FailoverOptions) *Client {
opt := failoverOpt.options()
2016-06-05 14:10:30 +03:00
opt.init()
2014-05-11 18:11:55 +04:00
failover := &sentinelFailover{
masterName: failoverOpt.MasterName,
sentinelAddrs: failoverOpt.SentinelAddrs,
2019-06-02 19:27:33 +03:00
password: failoverOpt.SentinelPassword,
2014-05-11 18:11:55 +04:00
opt: opt,
}
2016-06-05 14:10:30 +03:00
2018-01-20 13:26:33 +03:00
c := Client{
2019-05-31 17:03:20 +03:00
client: &client{
baseClient: baseClient{
opt: opt,
connPool: failover.Pool(),
onClose: failover.Close,
},
},
2019-07-04 11:18:06 +03:00
ctx: context.Background(),
}
2019-07-04 11:18:06 +03:00
c.init()
2016-06-05 14:10:30 +03:00
2018-01-20 13:26:33 +03:00
return &c
2014-05-11 18:11:55 +04:00
}
//------------------------------------------------------------------------------
2018-05-31 13:15:52 +03:00
type SentinelClient struct {
2019-05-31 17:37:34 +03:00
*baseClient
ctx context.Context
2014-05-11 18:11:55 +04:00
}
2018-05-31 13:15:52 +03:00
func NewSentinelClient(opt *Options) *SentinelClient {
2016-06-05 14:10:30 +03:00
opt.init()
2018-05-31 13:15:52 +03:00
c := &SentinelClient{
2019-05-31 17:37:34 +03:00
baseClient: &baseClient{
opt: opt,
connPool: newConnPool(opt),
},
2019-07-04 11:18:06 +03:00
ctx: context.Background(),
2014-05-11 18:11:55 +04:00
}
2018-05-31 13:15:52 +03:00
return c
2014-05-11 18:11:55 +04:00
}
func (c *SentinelClient) Context() context.Context {
2019-07-04 11:18:06 +03:00
return c.ctx
}
func (c *SentinelClient) WithContext(ctx context.Context) *SentinelClient {
if ctx == nil {
panic("nil context")
}
clone := *c
2019-05-31 17:03:20 +03:00
clone.ctx = ctx
return &clone
}
func (c *SentinelClient) Process(cmd Cmder) error {
2019-06-04 13:30:47 +03:00
return c.ProcessContext(c.ctx, cmd)
}
func (c *SentinelClient) ProcessContext(ctx context.Context, cmd Cmder) error {
return c.baseClient.process(ctx, cmd)
}
func (c *SentinelClient) pubSub() *PubSub {
2018-07-23 15:55:13 +03:00
pubsub := &PubSub{
2017-07-09 10:07:20 +03:00
opt: c.opt,
newConn: func(channels []string) (*pool.Conn, error) {
2019-06-14 16:00:03 +03:00
return c.newConn(context.TODO())
2014-05-11 18:11:55 +04:00
},
2017-07-09 10:07:20 +03:00
closeConn: c.connPool.CloseConn,
2014-05-11 18:11:55 +04:00
}
2018-07-23 15:55:13 +03:00
pubsub.init()
return pubsub
2014-05-11 18:11:55 +04:00
}
// Ping is used to test if a connection is still alive, or to
// measure latency.
func (c *SentinelClient) Ping() *StringCmd {
cmd := NewStringCmd("ping")
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
return cmd
}
// Subscribe subscribes the client to the specified channels.
// Channels can be omitted to create empty subscription.
func (c *SentinelClient) Subscribe(channels ...string) *PubSub {
pubsub := c.pubSub()
if len(channels) > 0 {
_ = pubsub.Subscribe(channels...)
}
return pubsub
}
// PSubscribe subscribes the client to the given patterns.
// Patterns can be omitted to create empty subscription.
func (c *SentinelClient) PSubscribe(channels ...string) *PubSub {
pubsub := c.pubSub()
if len(channels) > 0 {
_ = pubsub.PSubscribe(channels...)
}
return pubsub
}
2018-05-31 13:15:52 +03:00
func (c *SentinelClient) GetMasterAddrByName(name string) *StringSliceCmd {
cmd := NewStringSliceCmd("sentinel", "get-master-addr-by-name", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2014-05-11 18:11:55 +04:00
return cmd
}
2018-05-31 13:15:52 +03:00
func (c *SentinelClient) Sentinels(name string) *SliceCmd {
cmd := NewSliceCmd("sentinel", "sentinels", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2014-05-11 18:11:55 +04:00
return cmd
}
2019-02-20 13:39:33 +03:00
// Failover forces a failover as if the master was not reachable, and without
// asking for agreement to other Sentinels.
func (c *SentinelClient) Failover(name string) *StatusCmd {
cmd := NewStatusCmd("sentinel", "failover", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-02-20 13:39:33 +03:00
return cmd
}
2019-02-20 18:19:42 +03:00
// Reset resets all the masters with matching name. The pattern argument is a
// glob-style pattern. The reset process clears any previous state in a master
// (including a failover in progress), and removes every slave and sentinel
// already discovered and associated with the master.
func (c *SentinelClient) Reset(pattern string) *IntCmd {
cmd := NewIntCmd("sentinel", "reset", pattern)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-02-20 18:19:42 +03:00
return cmd
}
2019-02-21 13:28:23 +03:00
// FlushConfig forces Sentinel to rewrite its configuration on disk, including
// the current Sentinel state.
func (c *SentinelClient) FlushConfig() *StatusCmd {
cmd := NewStatusCmd("sentinel", "flushconfig")
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-02-21 13:28:23 +03:00
return cmd
}
2019-02-21 20:13:04 +03:00
// Master shows the state and info of the specified master.
func (c *SentinelClient) Master(name string) *StringStringMapCmd {
cmd := NewStringStringMapCmd("sentinel", "master", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-02-21 20:13:04 +03:00
return cmd
}
2019-05-25 23:31:06 +03:00
// Masters shows a list of monitored masters and their state.
func (c *SentinelClient) Masters() *SliceCmd {
cmd := NewSliceCmd("sentinel", "masters")
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-05-25 23:31:06 +03:00
return cmd
}
// Slaves shows a list of slaves for the specified master and their state.
func (c *SentinelClient) Slaves(name string) *SliceCmd {
cmd := NewSliceCmd("sentinel", "slaves", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-05-25 23:31:06 +03:00
return cmd
}
// CkQuorum checks if the current Sentinel configuration is able to reach the
// quorum needed to failover a master, and the majority needed to authorize the
// failover. This command should be used in monitoring systems to check if a
// Sentinel deployment is ok.
func (c *SentinelClient) CkQuorum(name string) *StringCmd {
cmd := NewStringCmd("sentinel", "ckquorum", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
2019-05-25 23:31:06 +03:00
return cmd
}
// Monitor tells the Sentinel to start monitoring a new master with the specified
2019-05-25 23:58:27 +03:00
// name, ip, port, and quorum.
func (c *SentinelClient) Monitor(name, ip, port, quorum string) *StringCmd {
cmd := NewStringCmd("sentinel", "monitor", name, ip, port, quorum)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
return cmd
}
// Set is used in order to change configuration parameters of a specific master.
func (c *SentinelClient) Set(name, option, value string) *StringCmd {
cmd := NewStringCmd("sentinel", "set", name, option, value)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
return cmd
}
// Remove is used in order to remove the specified master: the master will no
// longer be monitored, and will totally be removed from the internal state of
2019-05-25 23:58:27 +03:00
// the Sentinel.
func (c *SentinelClient) Remove(name string) *StringCmd {
cmd := NewStringCmd("sentinel", "remove", name)
2019-07-04 11:18:06 +03:00
_ = c.Process(cmd)
return cmd
}
2014-05-11 18:11:55 +04:00
type sentinelFailover struct {
sentinelAddrs []string
2019-06-02 19:27:33 +03:00
opt *Options
password string
2014-05-11 18:11:55 +04:00
pool *pool.ConnPool
2014-05-11 18:11:55 +04:00
poolOnce sync.Once
mu sync.RWMutex
masterName string
_masterAddr string
2018-05-31 13:15:52 +03:00
sentinel *SentinelClient
pubsub *PubSub
}
func (c *sentinelFailover) Close() error {
c.mu.Lock()
defer c.mu.Unlock()
2018-10-25 09:42:56 +03:00
if c.sentinel != nil {
return c.closeSentinel()
}
return nil
2014-05-11 18:11:55 +04:00
}
func (c *sentinelFailover) Pool() *pool.ConnPool {
c.poolOnce.Do(func() {
opt := *c.opt
opt.Dialer = c.dial
c.pool = newConnPool(&opt)
2014-05-11 18:11:55 +04:00
})
return c.pool
2014-05-11 18:11:55 +04:00
}
2019-07-04 11:18:06 +03:00
func (c *sentinelFailover) dial(ctx context.Context, network, _ string) (net.Conn, error) {
addr, err := c.MasterAddr()
2017-07-09 10:07:20 +03:00
if err != nil {
return nil, err
}
if c.opt.Dialer != nil {
return c.opt.Dialer(ctx, network, addr)
}
return net.DialTimeout("tcp", addr, c.opt.DialTimeout)
2017-07-09 10:07:20 +03:00
}
func (c *sentinelFailover) MasterAddr() (string, error) {
addr, err := c.masterAddr()
if err != nil {
return "", err
}
c.switchMaster(addr)
return addr, nil
}
func (c *sentinelFailover) masterAddr() (string, error) {
addr := c.getMasterAddr()
if addr != "" {
return addr, nil
2014-05-11 18:11:55 +04:00
}
c.mu.Lock()
defer c.mu.Unlock()
for i, sentinelAddr := range c.sentinelAddrs {
2018-05-31 13:15:52 +03:00
sentinel := NewSentinelClient(&Options{
Addr: sentinelAddr,
2014-05-11 18:11:55 +04:00
2019-06-02 19:27:33 +03:00
Password: c.password,
MaxRetries: c.opt.MaxRetries,
DialTimeout: c.opt.DialTimeout,
ReadTimeout: c.opt.ReadTimeout,
WriteTimeout: c.opt.WriteTimeout,
2014-05-11 18:11:55 +04:00
PoolSize: c.opt.PoolSize,
PoolTimeout: c.opt.PoolTimeout,
IdleTimeout: c.opt.IdleTimeout,
IdleCheckFrequency: c.opt.IdleCheckFrequency,
TLSConfig: c.opt.TLSConfig,
2014-05-11 18:11:55 +04:00
})
masterAddr, err := sentinel.GetMasterAddrByName(c.masterName).Result()
2014-05-11 18:11:55 +04:00
if err != nil {
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: GetMasterAddrByName master=%q failed: %s",
c.masterName, err)
2018-10-25 09:42:56 +03:00
_ = sentinel.Close()
continue
2014-05-11 18:11:55 +04:00
}
// Push working sentinel to the top.
c.sentinelAddrs[0], c.sentinelAddrs[i] = c.sentinelAddrs[i], c.sentinelAddrs[0]
c.setSentinel(sentinel)
addr := net.JoinHostPort(masterAddr[0], masterAddr[1])
return addr, nil
2014-05-11 18:11:55 +04:00
}
return "", errors.New("redis: all sentinels are unreachable")
}
func (c *sentinelFailover) getMasterAddr() string {
c.mu.RLock()
sentinel := c.sentinel
c.mu.RUnlock()
if sentinel == nil {
return ""
}
addr, err := sentinel.GetMasterAddrByName(c.masterName).Result()
if err != nil {
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: GetMasterAddrByName name=%q failed: %s",
c.masterName, err)
c.mu.Lock()
if c.sentinel == sentinel {
2019-07-04 11:18:06 +03:00
_ = c.closeSentinel()
}
c.mu.Unlock()
return ""
}
return net.JoinHostPort(addr[0], addr[1])
2018-07-23 15:55:13 +03:00
}
func (c *sentinelFailover) switchMaster(addr string) {
c.mu.RLock()
masterAddr := c._masterAddr
c.mu.RUnlock()
if masterAddr == addr {
2018-07-23 15:55:13 +03:00
return
}
c.mu.Lock()
defer c.mu.Unlock()
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: new master=%q addr=%q",
2018-07-23 15:55:13 +03:00
c.masterName, addr)
_ = c.Pool().Filter(func(cn *pool.Conn) bool {
return cn.RemoteAddr().String() != addr
})
2018-07-23 15:55:13 +03:00
c._masterAddr = addr
}
func (c *sentinelFailover) setSentinel(sentinel *SentinelClient) {
c.discoverSentinels(sentinel)
c.sentinel = sentinel
2018-11-11 13:13:00 +03:00
c.pubsub = sentinel.Subscribe("+switch-master")
go c.listen(c.pubsub)
}
func (c *sentinelFailover) closeSentinel() error {
2019-07-25 13:53:00 +03:00
firstErr := c.pubsub.Close()
2018-11-11 13:13:00 +03:00
c.pubsub = nil
2019-07-25 13:53:00 +03:00
err := c.sentinel.Close()
2019-07-04 11:18:06 +03:00
if err != nil && firstErr == nil {
2018-11-11 13:13:00 +03:00
firstErr = err
}
c.sentinel = nil
2018-11-11 13:13:00 +03:00
return firstErr
}
func (c *sentinelFailover) discoverSentinels(sentinel *SentinelClient) {
sentinels, err := sentinel.Sentinels(c.masterName).Result()
2014-05-11 18:11:55 +04:00
if err != nil {
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: Sentinels master=%q failed: %s", c.masterName, err)
2014-05-11 18:11:55 +04:00
return
}
for _, sentinel := range sentinels {
vals := sentinel.([]interface{})
for i := 0; i < len(vals); i += 2 {
key := vals[i].(string)
if key == "name" {
sentinelAddr := vals[i+1].(string)
if !contains(c.sentinelAddrs, sentinelAddr) {
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: discovered new sentinel=%q for master=%q",
sentinelAddr, c.masterName)
c.sentinelAddrs = append(c.sentinelAddrs, sentinelAddr)
2014-05-11 18:11:55 +04:00
}
}
}
}
}
2018-11-11 13:13:00 +03:00
func (c *sentinelFailover) listen(pubsub *PubSub) {
ch := pubsub.Channel()
2018-07-23 15:55:13 +03:00
for {
msg, ok := <-ch
if !ok {
break
2014-05-11 18:11:55 +04:00
}
if msg.Channel == "+switch-master" {
parts := strings.Split(msg.Payload, " ")
if parts[0] != c.masterName {
2019-06-17 12:32:40 +03:00
internal.Logger.Printf("sentinel: ignore addr for master=%q", parts[0])
continue
2014-05-11 18:11:55 +04:00
}
addr := net.JoinHostPort(parts[3], parts[4])
c.switchMaster(addr)
2014-05-11 18:11:55 +04:00
}
}
}
func contains(slice []string, str string) bool {
for _, s := range slice {
if s == str {
return true
}
}
return false
}