redis/cluster.go

1695 lines
35 KiB
Go
Raw Normal View History

2015-01-24 15:12:48 +03:00
package redis
import (
"context"
"crypto/tls"
2016-12-13 18:28:39 +03:00
"fmt"
"math"
"net"
"runtime"
2018-07-22 10:50:26 +03:00
"sort"
2015-01-24 15:12:48 +03:00
"sync"
"sync/atomic"
"time"
2015-12-30 16:53:45 +03:00
2020-03-11 17:29:16 +03:00
"github.com/go-redis/redis/v8/internal"
"github.com/go-redis/redis/v8/internal/hashtag"
"github.com/go-redis/redis/v8/internal/pool"
"github.com/go-redis/redis/v8/internal/proto"
2020-06-29 17:26:11 +03:00
"golang.org/x/exp/rand"
2015-01-24 15:12:48 +03:00
)
2017-08-31 15:22:47 +03:00
var errClusterNoNodes = fmt.Errorf("redis: cluster has no nodes")
2016-10-09 14:12:32 +03:00
// ClusterOptions are used to configure a cluster client and should be
// passed to NewClusterClient.
type ClusterOptions struct {
// A seed list of host:port addresses of cluster nodes.
Addrs []string
2020-06-10 15:04:12 +03:00
// NewClient creates a cluster node client with provided name and options.
NewClient func(opt *Options) *Client
// The maximum number of retries before giving up. Command is retried
// on network errors and MOVED/ASK redirects.
2018-06-29 10:45:05 +03:00
// Default is 8 retries.
MaxRedirects int
2017-07-09 13:10:07 +03:00
// Enables read-only commands on slave nodes.
ReadOnly bool
2017-07-09 13:10:07 +03:00
// Allows routing read-only commands to the closest master or slave node.
2018-05-17 16:09:56 +03:00
// It automatically enables ReadOnly.
RouteByLatency bool
// Allows routing read-only commands to the random master or slave node.
2018-06-29 10:45:05 +03:00
// It automatically enables ReadOnly.
RouteRandomly bool
2018-07-18 15:28:51 +03:00
// Optional function that returns cluster slots information.
2018-06-29 10:45:05 +03:00
// It is useful to manually create cluster of standalone Redis servers
2018-07-18 15:28:51 +03:00
// and load-balance read/write operations between master and slaves.
// It can use service like ZooKeeper to maintain configuration information
// and Cluster.ReloadState to manually trigger state reloading.
2018-06-29 10:45:05 +03:00
ClusterSlots func() ([]ClusterSlot, error)
// 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)
2019-05-18 14:00:07 +03:00
2020-06-10 10:36:22 +03:00
OnConnect func(ctx context.Context, cn *Conn) error
2017-05-25 14:16:39 +03:00
2020-05-21 08:59:20 +03:00
Username string
Password string
2017-07-09 13:10:07 +03:00
MaxRetries int
MinRetryBackoff time.Duration
MaxRetryBackoff time.Duration
DialTimeout time.Duration
ReadTimeout time.Duration
WriteTimeout time.Duration
// PoolSize applies per cluster node and not for the whole cluster.
PoolSize int
2018-08-12 10:08:21 +03:00
MinIdleConns int
MaxConnAge time.Duration
PoolTimeout time.Duration
IdleTimeout time.Duration
IdleCheckFrequency time.Duration
TLSConfig *tls.Config
}
func (opt *ClusterOptions) init() {
if opt.MaxRedirects == -1 {
opt.MaxRedirects = 0
} else if opt.MaxRedirects == 0 {
opt.MaxRedirects = 8
}
if (opt.RouteByLatency || opt.RouteRandomly) && opt.ClusterSlots == nil {
opt.ReadOnly = true
}
2017-07-09 13:10:07 +03:00
if opt.PoolSize == 0 {
opt.PoolSize = 5 * runtime.NumCPU()
}
2017-08-31 15:22:47 +03:00
switch opt.ReadTimeout {
case -1:
opt.ReadTimeout = 0
case 0:
opt.ReadTimeout = 3 * time.Second
}
switch opt.WriteTimeout {
case -1:
opt.WriteTimeout = 0
case 0:
opt.WriteTimeout = opt.ReadTimeout
}
2017-07-09 13:10:07 +03:00
switch opt.MinRetryBackoff {
case -1:
opt.MinRetryBackoff = 0
case 0:
opt.MinRetryBackoff = 8 * time.Millisecond
}
switch opt.MaxRetryBackoff {
case -1:
opt.MaxRetryBackoff = 0
case 0:
opt.MaxRetryBackoff = 512 * time.Millisecond
}
if opt.NewClient == nil {
opt.NewClient = NewClient
}
}
func (opt *ClusterOptions) clientOptions() *Options {
const disableIdleCheck = -1
return &Options{
2019-05-18 14:00:07 +03:00
Dialer: opt.Dialer,
2017-05-25 14:16:39 +03:00
OnConnect: opt.OnConnect,
2017-07-09 13:10:07 +03:00
MaxRetries: opt.MaxRetries,
MinRetryBackoff: opt.MinRetryBackoff,
MaxRetryBackoff: opt.MaxRetryBackoff,
2020-05-21 08:59:20 +03:00
Username: opt.Username,
2017-07-09 13:10:07 +03:00
Password: opt.Password,
readOnly: opt.ReadOnly,
DialTimeout: opt.DialTimeout,
ReadTimeout: opt.ReadTimeout,
WriteTimeout: opt.WriteTimeout,
2018-08-12 10:08:21 +03:00
PoolSize: opt.PoolSize,
MinIdleConns: opt.MinIdleConns,
MaxConnAge: opt.MaxConnAge,
PoolTimeout: opt.PoolTimeout,
IdleTimeout: opt.IdleTimeout,
IdleCheckFrequency: disableIdleCheck,
TLSConfig: opt.TLSConfig,
}
}
//------------------------------------------------------------------------------
type clusterNode struct {
Client *Client
2017-07-09 13:10:07 +03:00
latency uint32 // atomic
2018-02-15 14:00:54 +03:00
generation uint32 // atomic
failing uint32 // atomic
2016-10-09 11:18:57 +03:00
}
func newClusterNode(clOpt *ClusterOptions, addr string) *clusterNode {
opt := clOpt.clientOptions()
opt.Addr = addr
node := clusterNode{
Client: clOpt.NewClient(opt),
}
node.latency = math.MaxUint32
if clOpt.RouteByLatency {
go node.updateLatency()
}
return &node
}
2018-05-17 16:09:56 +03:00
func (n *clusterNode) String() string {
return n.Client.String()
}
2018-02-15 14:00:54 +03:00
func (n *clusterNode) Close() error {
return n.Client.Close()
}
2016-12-16 17:26:48 +03:00
func (n *clusterNode) updateLatency() {
const probes = 10
var latency uint32
2016-12-16 17:26:48 +03:00
for i := 0; i < probes; i++ {
start := time.Now()
2020-03-11 17:26:42 +03:00
n.Client.Ping(context.TODO())
probe := uint32(time.Since(start) / time.Microsecond)
latency = (latency + probe) / 2
2016-12-16 17:26:48 +03:00
}
atomic.StoreUint32(&n.latency, latency)
}
func (n *clusterNode) Latency() time.Duration {
latency := atomic.LoadUint32(&n.latency)
return time.Duration(latency) * time.Microsecond
}
func (n *clusterNode) MarkAsFailing() {
atomic.StoreUint32(&n.failing, uint32(time.Now().Unix()))
2016-12-16 17:26:48 +03:00
}
func (n *clusterNode) Failing() bool {
const timeout = 15 // 15 seconds
failing := atomic.LoadUint32(&n.failing)
if failing == 0 {
return false
}
if time.Now().Unix()-int64(failing) < timeout {
return true
}
atomic.StoreUint32(&n.failing, 0)
return false
}
2017-07-09 13:10:07 +03:00
func (n *clusterNode) Generation() uint32 {
2018-02-15 14:00:54 +03:00
return atomic.LoadUint32(&n.generation)
2017-07-09 13:10:07 +03:00
}
func (n *clusterNode) SetGeneration(gen uint32) {
2018-02-15 14:00:54 +03:00
for {
v := atomic.LoadUint32(&n.generation)
if gen < v || atomic.CompareAndSwapUint32(&n.generation, v, gen) {
break
}
2017-07-09 13:10:07 +03:00
}
}
//------------------------------------------------------------------------------
2015-01-24 15:12:48 +03:00
type clusterNodes struct {
2016-03-17 19:00:47 +03:00
opt *ClusterOptions
2020-07-09 11:35:13 +03:00
mu sync.RWMutex
addrs []string
nodes map[string]*clusterNode
activeAddrs []string
closed bool
2018-02-15 14:00:54 +03:00
2018-05-17 14:36:51 +03:00
_generation uint32 // atomic
2015-01-24 15:12:48 +03:00
}
func newClusterNodes(opt *ClusterOptions) *clusterNodes {
return &clusterNodes{
2018-02-15 14:00:54 +03:00
opt: opt,
2020-07-09 11:35:13 +03:00
addrs: opt.Addrs,
nodes: make(map[string]*clusterNode),
2015-01-24 15:12:48 +03:00
}
}
func (c *clusterNodes) Close() error {
c.mu.Lock()
defer c.mu.Unlock()
if c.closed {
return nil
}
c.closed = true
var firstErr error
2020-07-09 11:35:13 +03:00
for _, node := range c.nodes {
if err := node.Client.Close(); err != nil && firstErr == nil {
firstErr = err
}
}
2018-02-15 14:00:54 +03:00
2020-07-09 11:35:13 +03:00
c.nodes = nil
c.activeAddrs = nil
return firstErr
2016-03-17 19:00:47 +03:00
}
2017-09-11 08:58:56 +03:00
func (c *clusterNodes) Addrs() ([]string, error) {
2018-02-15 14:00:54 +03:00
var addrs []string
2017-08-31 15:22:47 +03:00
c.mu.RLock()
2017-09-11 08:58:56 +03:00
closed := c.closed
2018-02-15 14:00:54 +03:00
if !closed {
2020-07-09 11:35:13 +03:00
if len(c.activeAddrs) > 0 {
addrs = c.activeAddrs
2018-02-15 14:00:54 +03:00
} else {
2020-07-09 11:35:13 +03:00
addrs = c.addrs
2018-02-15 14:00:54 +03:00
}
}
2017-09-11 08:58:56 +03:00
c.mu.RUnlock()
2017-08-31 15:22:47 +03:00
2017-09-11 08:58:56 +03:00
if closed {
return nil, pool.ErrClosed
2017-08-31 15:22:47 +03:00
}
2017-09-11 08:58:56 +03:00
if len(addrs) == 0 {
return nil, errClusterNoNodes
2017-08-31 15:22:47 +03:00
}
2017-09-11 08:58:56 +03:00
return addrs, nil
2017-08-31 15:22:47 +03:00
}
2017-07-09 13:10:07 +03:00
func (c *clusterNodes) NextGeneration() uint32 {
2018-05-17 14:36:51 +03:00
return atomic.AddUint32(&c._generation, 1)
2017-07-09 13:10:07 +03:00
}
// GC removes unused nodes.
func (c *clusterNodes) GC(generation uint32) {
2019-07-25 13:53:00 +03:00
//nolint:prealloc
2017-07-09 13:10:07 +03:00
var collected []*clusterNode
2020-07-09 11:35:13 +03:00
2017-07-09 13:10:07 +03:00
c.mu.Lock()
2020-07-09 11:35:13 +03:00
c.activeAddrs = c.activeAddrs[:0]
for addr, node := range c.nodes {
2017-07-09 13:10:07 +03:00
if node.Generation() >= generation {
2020-07-09 11:35:13 +03:00
c.activeAddrs = append(c.activeAddrs, addr)
2017-07-09 13:10:07 +03:00
continue
}
2020-07-09 11:35:13 +03:00
delete(c.nodes, addr)
2017-07-09 13:10:07 +03:00
collected = append(collected, node)
}
2020-07-09 11:35:13 +03:00
2017-07-09 13:10:07 +03:00
c.mu.Unlock()
for _, node := range collected {
_ = node.Client.Close()
}
2017-07-09 13:10:07 +03:00
}
2018-05-17 15:21:51 +03:00
func (c *clusterNodes) Get(addr string) (*clusterNode, error) {
2019-06-29 10:28:33 +03:00
node, err := c.get(addr)
if err != nil {
return nil, err
}
if node != nil {
return node, nil
2016-03-17 19:00:47 +03:00
}
c.mu.Lock()
defer c.mu.Unlock()
if c.closed {
return nil, pool.ErrClosed
}
2020-07-09 11:35:13 +03:00
node, ok := c.nodes[addr]
if ok {
2020-07-19 09:49:00 +03:00
return node, nil
2015-03-18 13:41:24 +03:00
}
node = newClusterNode(c.opt, addr)
2015-03-18 13:41:24 +03:00
2020-07-09 11:35:13 +03:00
c.addrs = appendIfNotExists(c.addrs, addr)
c.nodes[addr] = node
2018-02-15 14:00:54 +03:00
2020-07-19 09:49:00 +03:00
return node, nil
}
2015-01-24 15:12:48 +03:00
2019-06-29 10:28:33 +03:00
func (c *clusterNodes) get(addr string) (*clusterNode, error) {
var node *clusterNode
var err error
c.mu.RLock()
if c.closed {
err = pool.ErrClosed
} else {
2020-07-09 11:35:13 +03:00
node = c.nodes[addr]
2019-06-29 10:28:33 +03:00
}
c.mu.RUnlock()
return node, err
}
2018-03-06 18:10:01 +03:00
func (c *clusterNodes) All() ([]*clusterNode, error) {
c.mu.RLock()
defer c.mu.RUnlock()
if c.closed {
return nil, pool.ErrClosed
}
2020-07-09 11:35:13 +03:00
cp := make([]*clusterNode, 0, len(c.nodes))
for _, node := range c.nodes {
2018-03-06 18:10:01 +03:00
cp = append(cp, node)
}
return cp, nil
}
func (c *clusterNodes) Random() (*clusterNode, error) {
2017-09-11 08:58:56 +03:00
addrs, err := c.Addrs()
if err != nil {
return nil, err
}
2018-02-15 14:00:54 +03:00
n := rand.Intn(len(addrs))
2019-06-29 10:28:33 +03:00
return c.Get(addrs[n])
2015-01-24 15:12:48 +03:00
}
//------------------------------------------------------------------------------
2018-07-22 10:50:26 +03:00
type clusterSlot struct {
start, end int
nodes []*clusterNode
}
type clusterSlotSlice []*clusterSlot
func (p clusterSlotSlice) Len() int {
return len(p)
}
func (p clusterSlotSlice) Less(i, j int) bool {
return p[i].start < p[j].start
}
func (p clusterSlotSlice) Swap(i, j int) {
p[i], p[j] = p[j], p[i]
}
type clusterState struct {
2017-07-09 13:10:07 +03:00
nodes *clusterNodes
2018-05-17 16:09:56 +03:00
Masters []*clusterNode
Slaves []*clusterNode
2017-07-09 13:10:07 +03:00
2018-07-22 10:50:26 +03:00
slots []*clusterSlot
2017-07-09 13:10:07 +03:00
generation uint32
createdAt time.Time
}
2018-05-17 16:09:56 +03:00
func newClusterState(
nodes *clusterNodes, slots []ClusterSlot, origin string,
) (*clusterState, error) {
c := clusterState{
nodes: nodes,
2017-07-09 13:10:07 +03:00
2018-07-22 10:50:26 +03:00
slots: make([]*clusterSlot, 0, len(slots)),
generation: nodes.NextGeneration(),
createdAt: time.Now(),
}
originHost, _, _ := net.SplitHostPort(origin)
isLoopbackOrigin := isLoopback(originHost)
for _, slot := range slots {
var nodes []*clusterNode
2017-07-09 13:10:07 +03:00
for i, slotNode := range slot.Nodes {
addr := slotNode.Addr
if !isLoopbackOrigin {
addr = replaceLoopbackHost(addr, originHost)
}
2019-06-29 10:28:33 +03:00
node, err := c.nodes.Get(addr)
if err != nil {
return nil, err
}
2017-07-09 13:10:07 +03:00
node.SetGeneration(c.generation)
nodes = append(nodes, node)
2017-07-09 13:10:07 +03:00
if i == 0 {
2018-05-17 16:09:56 +03:00
c.Masters = appendUniqueNode(c.Masters, node)
2017-07-09 13:10:07 +03:00
} else {
2018-05-17 16:09:56 +03:00
c.Slaves = appendUniqueNode(c.Slaves, node)
2017-07-09 13:10:07 +03:00
}
}
2018-07-22 10:50:26 +03:00
c.slots = append(c.slots, &clusterSlot{
start: slot.Start,
end: slot.End,
nodes: nodes,
})
}
2018-07-22 10:50:26 +03:00
sort.Sort(clusterSlotSlice(c.slots))
2018-03-06 18:10:01 +03:00
time.AfterFunc(time.Minute, func() {
nodes.GC(c.generation)
})
return &c, nil
}
func replaceLoopbackHost(nodeAddr, originHost string) string {
nodeHost, nodePort, err := net.SplitHostPort(nodeAddr)
if err != nil {
return nodeAddr
}
nodeIP := net.ParseIP(nodeHost)
if nodeIP == nil {
return nodeAddr
}
if !nodeIP.IsLoopback() {
return nodeAddr
}
// Use origin host which is not loopback and node port.
return net.JoinHostPort(originHost, nodePort)
}
func isLoopback(host string) bool {
ip := net.ParseIP(host)
if ip == nil {
return true
}
return ip.IsLoopback()
}
func (c *clusterState) slotMasterNode(slot int) (*clusterNode, error) {
nodes := c.slotNodes(slot)
if len(nodes) > 0 {
return nodes[0], nil
}
return c.nodes.Random()
}
func (c *clusterState) slotSlaveNode(slot int) (*clusterNode, error) {
nodes := c.slotNodes(slot)
switch len(nodes) {
case 0:
return c.nodes.Random()
case 1:
return nodes[0], nil
case 2:
if slave := nodes[1]; !slave.Failing() {
2016-10-09 11:18:57 +03:00
return slave, nil
}
return nodes[0], nil
default:
2016-10-09 11:18:57 +03:00
var slave *clusterNode
for i := 0; i < 10; i++ {
n := rand.Intn(len(nodes)-1) + 1
slave = nodes[n]
if !slave.Failing() {
2018-11-21 11:49:30 +03:00
return slave, nil
2016-10-09 11:18:57 +03:00
}
}
2018-11-21 11:49:30 +03:00
// All slaves are loading - use master.
return nodes[0], nil
}
}
func (c *clusterState) slotClosestNode(slot int) (*clusterNode, error) {
2016-12-16 17:26:48 +03:00
const threshold = time.Millisecond
nodes := c.slotNodes(slot)
if len(nodes) == 0 {
return c.nodes.Random()
}
var node *clusterNode
for _, n := range nodes {
if n.Failing() {
2016-12-16 17:26:48 +03:00
continue
}
if node == nil || node.Latency()-n.Latency() > threshold {
node = n
2015-04-04 16:46:57 +03:00
}
}
if node != nil {
return node, nil
}
// If all nodes are failing - return random node
return c.nodes.Random()
2015-04-04 16:46:57 +03:00
}
func (c *clusterState) slotRandomNode(slot int) (*clusterNode, error) {
nodes := c.slotNodes(slot)
if len(nodes) == 0 {
return c.nodes.Random()
}
n := rand.Intn(len(nodes))
return nodes[n], nil
}
func (c *clusterState) slotNodes(slot int) []*clusterNode {
2018-07-22 10:50:26 +03:00
i := sort.Search(len(c.slots), func(i int) bool {
return c.slots[i].end >= slot
})
if i >= len(c.slots) {
return nil
}
x := c.slots[i]
if slot >= x.start && slot <= x.end {
return x.nodes
}
return nil
}
//------------------------------------------------------------------------------
2018-03-06 18:10:01 +03:00
type clusterStateHolder struct {
2020-03-11 17:26:42 +03:00
load func(ctx context.Context) (*clusterState, error)
2018-03-06 18:10:01 +03:00
state atomic.Value
reloading uint32 // atomic
2018-03-06 18:10:01 +03:00
}
2020-03-11 17:26:42 +03:00
func newClusterStateHolder(fn func(ctx context.Context) (*clusterState, error)) *clusterStateHolder {
2018-03-06 18:10:01 +03:00
return &clusterStateHolder{
load: fn,
}
}
2020-03-11 17:26:42 +03:00
func (c *clusterStateHolder) Reload(ctx context.Context) (*clusterState, error) {
state, err := c.load(ctx)
2018-03-06 18:10:01 +03:00
if err != nil {
return nil, err
}
c.state.Store(state)
return state, nil
}
2020-03-11 17:26:42 +03:00
func (c *clusterStateHolder) LazyReload(ctx context.Context) {
2018-03-06 18:10:01 +03:00
if !atomic.CompareAndSwapUint32(&c.reloading, 0, 1) {
return
}
go func() {
defer atomic.StoreUint32(&c.reloading, 0)
2020-03-11 17:26:42 +03:00
_, err := c.Reload(ctx)
2018-11-24 14:16:21 +03:00
if err != nil {
return
2018-03-06 18:10:01 +03:00
}
2020-07-09 10:39:46 +03:00
time.Sleep(200 * time.Millisecond)
2018-03-06 18:10:01 +03:00
}()
}
2020-03-11 17:26:42 +03:00
func (c *clusterStateHolder) Get(ctx context.Context) (*clusterState, error) {
2018-03-06 18:10:01 +03:00
v := c.state.Load()
if v != nil {
state := v.(*clusterState)
2020-06-29 17:39:59 +03:00
if time.Since(state.createdAt) > 10*time.Second {
2020-03-11 17:26:42 +03:00
c.LazyReload(ctx)
}
return state, nil
2018-03-06 18:10:01 +03:00
}
2020-03-11 17:26:42 +03:00
return c.Reload(ctx)
2018-03-06 18:10:01 +03:00
}
2020-03-11 17:26:42 +03:00
func (c *clusterStateHolder) ReloadOrGet(ctx context.Context) (*clusterState, error) {
state, err := c.Reload(ctx)
2018-06-29 10:45:05 +03:00
if err == nil {
return state, nil
}
2020-03-11 17:26:42 +03:00
return c.Get(ctx)
2018-06-29 10:45:05 +03:00
}
2018-03-06 18:10:01 +03:00
//------------------------------------------------------------------------------
2019-05-31 17:03:20 +03:00
type clusterClient struct {
2018-03-06 15:50:48 +03:00
opt *ClusterOptions
nodes *clusterNodes
2019-07-25 13:53:00 +03:00
state *clusterStateHolder //nolint:structcheck
cmdsInfoCache *cmdsInfoCache //nolint:structcheck
2019-05-31 17:03:20 +03:00
}
2018-02-15 14:00:54 +03:00
2019-05-31 17:03:20 +03:00
// ClusterClient is a Redis Cluster client representing a pool of zero
// or more underlying connections. It's safe for concurrent use by
// multiple goroutines.
type ClusterClient struct {
*clusterClient
2019-08-24 12:22:52 +03:00
cmdable
hooks
ctx context.Context
}
// NewClusterClient returns a Redis Cluster client as described in
// http://redis.io/topics/cluster-spec.
func NewClusterClient(opt *ClusterOptions) *ClusterClient {
opt.init()
c := &ClusterClient{
2019-05-31 17:03:20 +03:00
clusterClient: &clusterClient{
opt: opt,
nodes: newClusterNodes(opt),
},
2019-07-04 11:18:06 +03:00
ctx: context.Background(),
}
2018-03-06 18:10:01 +03:00
c.state = newClusterStateHolder(c.loadState)
2018-05-17 15:21:51 +03:00
c.cmdsInfoCache = newCmdsInfoCache(c.cmdsInfo)
2019-08-24 12:22:52 +03:00
c.cmdable = c.Process
2018-01-20 13:26:33 +03:00
if opt.IdleCheckFrequency > 0 {
go c.reaper(opt.IdleCheckFrequency)
}
return c
}
func (c *ClusterClient) Context() context.Context {
2019-07-04 11:18:06 +03:00
return c.ctx
}
func (c *ClusterClient) WithContext(ctx context.Context) *ClusterClient {
if ctx == nil {
panic("nil context")
}
clone := *c
2019-08-24 12:22:52 +03:00
clone.cmdable = clone.Process
clone.hooks.lock()
2019-05-31 17:03:20 +03:00
clone.ctx = ctx
return &clone
2018-03-07 14:50:14 +03:00
}
2017-03-20 13:15:21 +03:00
// Options returns read-only Options that were used to create the client.
func (c *ClusterClient) Options() *ClusterOptions {
return c.opt
}
// ReloadState reloads cluster state. If available it calls ClusterSlots func
// to get cluster slots information.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) ReloadState(ctx context.Context) error {
_, err := c.state.Reload(ctx)
2017-08-31 15:22:47 +03:00
return err
}
// Close closes the cluster client, releasing any open resources.
//
// It is rare to Close a ClusterClient, as the ClusterClient is meant
// to be long-lived and shared between many goroutines.
func (c *ClusterClient) Close() error {
return c.nodes.Close()
}
2018-08-12 11:11:01 +03:00
// Do creates a Cmd from the args and processes the cmd.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) Do(ctx context.Context, args ...interface{}) *Cmd {
cmd := NewCmd(ctx, args...)
_ = c.Process(ctx, cmd)
2018-08-12 11:11:01 +03:00
return cmd
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) Process(ctx context.Context, cmd Cmder) error {
2019-06-04 13:30:47 +03:00
return c.hooks.process(ctx, cmd, c.process)
2018-01-20 13:26:33 +03:00
}
2019-06-04 13:30:47 +03:00
func (c *ClusterClient) process(ctx context.Context, cmd Cmder) error {
err := c._process(ctx, cmd)
if err != nil {
2020-02-03 12:53:47 +03:00
cmd.SetErr(err)
return err
}
return nil
}
func (c *ClusterClient) _process(ctx context.Context, cmd Cmder) error {
cmdInfo := c.cmdInfo(cmd.Name())
slot := c.cmdSlot(cmd)
2018-02-27 15:50:08 +03:00
var node *clusterNode
2016-06-17 15:09:38 +03:00
var ask bool
var lastErr error
2016-06-05 14:10:30 +03:00
for attempt := 0; attempt <= c.opt.MaxRedirects; attempt++ {
2017-07-09 13:10:07 +03:00
if attempt > 0 {
2019-07-30 12:13:00 +03:00
if err := internal.Sleep(ctx, c.retryBackoff(attempt)); err != nil {
return err
}
2017-07-09 13:10:07 +03:00
}
2018-02-27 15:50:08 +03:00
if node == nil {
var err error
2020-03-11 17:26:42 +03:00
node, err = c.cmdNode(ctx, cmdInfo, slot)
2018-02-27 15:50:08 +03:00
if err != nil {
return err
2018-02-27 15:50:08 +03:00
}
}
2015-01-24 15:12:48 +03:00
if ask {
pipe := node.Client.Pipeline()
2020-03-11 17:26:42 +03:00
_ = pipe.Process(ctx, NewCmd(ctx, "asking"))
_ = pipe.Process(ctx, cmd)
_, lastErr = pipe.Exec(ctx)
_ = pipe.Close()
2015-01-24 15:12:48 +03:00
ask = false
} else {
2020-03-11 17:26:42 +03:00
lastErr = node.Client.Process(ctx, cmd)
2015-01-24 15:12:48 +03:00
}
2017-07-09 13:10:07 +03:00
// If there is no error - we are done.
if lastErr == nil {
return nil
2015-01-24 15:12:48 +03:00
}
2020-06-30 11:13:15 +03:00
if isReadOnly := isReadOnlyError(lastErr); isReadOnly || lastErr == pool.ErrClosed {
if isReadOnly {
c.state.LazyReload(ctx)
}
node = nil
continue
}
2015-01-24 15:12:48 +03:00
2018-11-21 11:49:30 +03:00
// If slave is loading - pick another node.
if c.opt.ReadOnly && isLoadingError(lastErr) {
node.MarkAsFailing()
2018-11-21 11:49:30 +03:00
node = nil
2016-10-09 11:18:57 +03:00
continue
}
2015-03-18 13:41:24 +03:00
var moved bool
var addr string
moved, ask, addr = isMovedError(lastErr)
2015-03-18 13:41:24 +03:00
if moved || ask {
var err error
2019-06-29 10:28:33 +03:00
node, err = c.nodes.Get(addr)
2018-02-27 15:50:08 +03:00
if err != nil {
return err
2016-06-17 15:09:38 +03:00
}
2015-03-18 13:41:24 +03:00
continue
2015-01-24 15:12:48 +03:00
}
2020-07-24 14:57:12 +03:00
if shouldRetry(lastErr, cmd.readTimeout() == nil) {
// First retry the same node.
if attempt == 0 {
continue
}
// Second try another node.
node.MarkAsFailing()
node = nil
continue
}
return lastErr
2015-01-24 15:12:48 +03:00
}
return lastErr
2016-06-17 15:09:38 +03:00
}
2017-07-09 13:10:07 +03:00
// ForEachMaster concurrently calls the fn on each master node in the cluster.
// It returns the first error if any.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) ForEachMaster(
ctx context.Context,
fn func(ctx context.Context, client *Client) error,
) error {
state, err := c.state.ReloadOrGet(ctx)
2017-08-31 15:22:47 +03:00
if err != nil {
2018-06-29 10:45:05 +03:00
return err
}
var wg sync.WaitGroup
errCh := make(chan error, 1)
2020-02-14 15:30:07 +03:00
2018-05-17 16:09:56 +03:00
for _, master := range state.Masters {
wg.Add(1)
go func(node *clusterNode) {
defer wg.Done()
2020-03-11 17:26:42 +03:00
err := fn(ctx, node.Client)
if err != nil {
select {
case errCh <- err:
default:
}
}
2017-07-09 13:10:07 +03:00
}(master)
}
2020-02-14 15:30:07 +03:00
wg.Wait()
select {
case err := <-errCh:
return err
default:
return nil
}
}
2017-07-09 13:10:07 +03:00
// ForEachSlave concurrently calls the fn on each slave node in the cluster.
2016-06-17 15:09:38 +03:00
// It returns the first error if any.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) ForEachSlave(
ctx context.Context,
fn func(ctx context.Context, client *Client) error,
) error {
state, err := c.state.ReloadOrGet(ctx)
2017-08-31 15:22:47 +03:00
if err != nil {
2018-06-29 10:45:05 +03:00
return err
}
2016-06-17 15:09:38 +03:00
var wg sync.WaitGroup
errCh := make(chan error, 1)
2020-02-14 15:30:07 +03:00
2018-05-17 16:09:56 +03:00
for _, slave := range state.Slaves {
2016-06-17 15:09:38 +03:00
wg.Add(1)
go func(node *clusterNode) {
defer wg.Done()
2020-03-11 17:26:42 +03:00
err := fn(ctx, node.Client)
2016-06-17 15:09:38 +03:00
if err != nil {
select {
case errCh <- err:
default:
2016-06-17 15:09:38 +03:00
}
}
2017-07-09 13:10:07 +03:00
}(slave)
2016-06-17 15:09:38 +03:00
}
2020-02-14 15:30:07 +03:00
2016-06-17 15:09:38 +03:00
wg.Wait()
select {
case err := <-errCh:
return err
default:
return nil
}
2015-01-24 15:12:48 +03:00
}
2020-06-10 15:04:12 +03:00
// ForEachShard concurrently calls the fn on each known node in the cluster.
2017-07-09 13:10:07 +03:00
// It returns the first error if any.
2020-06-10 15:04:12 +03:00
func (c *ClusterClient) ForEachShard(
2020-03-11 17:26:42 +03:00
ctx context.Context,
fn func(ctx context.Context, client *Client) error,
) error {
state, err := c.state.ReloadOrGet(ctx)
2017-08-31 15:22:47 +03:00
if err != nil {
2018-06-29 10:45:05 +03:00
return err
2017-07-09 13:10:07 +03:00
}
var wg sync.WaitGroup
errCh := make(chan error, 1)
2020-02-14 15:30:07 +03:00
2017-07-09 13:10:07 +03:00
worker := func(node *clusterNode) {
defer wg.Done()
2020-03-11 17:26:42 +03:00
err := fn(ctx, node.Client)
2017-07-09 13:10:07 +03:00
if err != nil {
select {
case errCh <- err:
default:
}
}
}
2018-05-17 16:09:56 +03:00
for _, node := range state.Masters {
2017-07-09 13:10:07 +03:00
wg.Add(1)
go worker(node)
}
2018-05-17 16:09:56 +03:00
for _, node := range state.Slaves {
2017-07-09 13:10:07 +03:00
wg.Add(1)
go worker(node)
}
wg.Wait()
2020-02-14 15:30:07 +03:00
2017-07-09 13:10:07 +03:00
select {
case err := <-errCh:
return err
default:
return nil
}
}
// PoolStats returns accumulated connection pool stats.
func (c *ClusterClient) PoolStats() *PoolStats {
2017-03-04 14:04:27 +03:00
var acc PoolStats
2020-03-11 17:26:42 +03:00
state, _ := c.state.Get(context.TODO())
2017-07-09 13:10:07 +03:00
if state == nil {
2017-03-04 14:04:27 +03:00
return &acc
}
2018-05-17 16:09:56 +03:00
for _, node := range state.Masters {
2017-07-09 13:10:07 +03:00
s := node.Client.connPool.Stats()
acc.Hits += s.Hits
acc.Misses += s.Misses
2017-07-09 13:10:07 +03:00
acc.Timeouts += s.Timeouts
2017-07-09 13:10:07 +03:00
acc.TotalConns += s.TotalConns
2018-08-12 10:08:21 +03:00
acc.IdleConns += s.IdleConns
acc.StaleConns += s.StaleConns
2017-07-09 13:10:07 +03:00
}
2018-05-17 16:09:56 +03:00
for _, node := range state.Slaves {
s := node.Client.connPool.Stats()
acc.Hits += s.Hits
acc.Misses += s.Misses
acc.Timeouts += s.Timeouts
acc.TotalConns += s.TotalConns
2018-08-12 10:08:21 +03:00
acc.IdleConns += s.IdleConns
acc.StaleConns += s.StaleConns
2015-01-24 15:12:48 +03:00
}
2017-07-09 13:10:07 +03:00
return &acc
}
2015-01-24 15:12:48 +03:00
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) loadState(ctx context.Context) (*clusterState, error) {
2018-06-29 10:45:05 +03:00
if c.opt.ClusterSlots != nil {
slots, err := c.opt.ClusterSlots()
if err != nil {
return nil, err
}
return newClusterState(c.nodes, slots, "")
}
2018-03-06 18:10:01 +03:00
addrs, err := c.nodes.Addrs()
2017-03-04 14:04:27 +03:00
if err != nil {
return nil, err
}
2018-03-06 18:10:01 +03:00
var firstErr error
2020-07-09 11:35:13 +03:00
2020-06-29 17:26:11 +03:00
for _, idx := range rand.Perm(len(addrs)) {
addr := addrs[idx]
2019-06-29 10:28:33 +03:00
node, err := c.nodes.Get(addr)
2018-03-06 18:10:01 +03:00
if err != nil {
if firstErr == nil {
firstErr = err
}
continue
}
2017-03-04 14:04:27 +03:00
2020-03-11 17:26:42 +03:00
slots, err := node.Client.ClusterSlots(ctx).Result()
2018-03-06 18:10:01 +03:00
if err != nil {
if firstErr == nil {
firstErr = err
}
continue
}
2015-01-24 15:12:48 +03:00
2018-03-06 18:10:01 +03:00
return newClusterState(c.nodes, slots, node.Client.opt.Addr)
2018-02-15 14:00:54 +03:00
}
/*
* No node is connectable. It's possible that all nodes' IP has changed.
2020-07-09 11:35:13 +03:00
* Clear activeAddrs to let client be able to re-connect using the initial
* setting of the addresses (e.g. [redis-cluster-0:6379, redis-cluster-1:6379]),
* which might have chance to resolve domain name and get updated IP address.
*/
c.nodes.mu.Lock()
2020-07-09 11:35:13 +03:00
c.nodes.activeAddrs = nil
c.nodes.mu.Unlock()
2018-03-06 18:10:01 +03:00
return nil, firstErr
2018-02-15 14:00:54 +03:00
}
// reaper closes idle connections to the cluster.
func (c *ClusterClient) reaper(idleCheckFrequency time.Duration) {
ticker := time.NewTicker(idleCheckFrequency)
defer ticker.Stop()
2017-04-02 17:10:47 +03:00
for range ticker.C {
nodes, err := c.nodes.All()
if err != nil {
break
}
for _, node := range nodes {
_, err := node.Client.connPool.(*pool.ConnPool).ReapStaleConns()
2016-03-17 19:00:47 +03:00
if err != nil {
internal.Logger.Printf(c.Context(), "ReapStaleConns failed: %s", err)
}
}
}
}
2017-05-02 18:00:53 +03:00
func (c *ClusterClient) Pipeline() Pipeliner {
pipe := Pipeline{
2019-07-25 13:28:15 +03:00
ctx: c.ctx,
2018-01-20 13:26:33 +03:00
exec: c.processPipeline,
}
2019-05-31 17:03:20 +03:00
pipe.init()
return &pipe
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) Pipelined(ctx context.Context, fn func(Pipeliner) error) ([]Cmder, error) {
return c.Pipeline().Pipelined(ctx, fn)
}
2019-06-04 13:30:47 +03:00
func (c *ClusterClient) processPipeline(ctx context.Context, cmds []Cmder) error {
2019-07-04 11:18:06 +03:00
return c.hooks.processPipeline(ctx, cmds, c._processPipeline)
2018-01-20 13:26:33 +03:00
}
2019-06-04 13:30:47 +03:00
func (c *ClusterClient) _processPipeline(ctx context.Context, cmds []Cmder) error {
2018-09-11 13:09:16 +03:00
cmdsMap := newCmdsMap()
2020-03-11 17:26:42 +03:00
err := c.mapCmdsByNode(ctx, cmdsMap, cmds)
2016-12-13 18:28:39 +03:00
if err != nil {
2017-08-31 15:22:47 +03:00
setCmdsErr(cmds, err)
2016-12-13 18:28:39 +03:00
return err
}
2017-08-31 15:22:47 +03:00
for attempt := 0; attempt <= c.opt.MaxRedirects; attempt++ {
if attempt > 0 {
2019-07-30 12:13:00 +03:00
if err := internal.Sleep(ctx, c.retryBackoff(attempt)); err != nil {
setCmdsErr(cmds, err)
2019-07-30 12:13:00 +03:00
return err
}
2017-08-31 15:22:47 +03:00
}
2018-09-11 13:09:16 +03:00
failedCmds := newCmdsMap()
var wg sync.WaitGroup
2018-09-11 13:09:16 +03:00
for node, cmds := range cmdsMap.m {
wg.Add(1)
go func(node *clusterNode, cmds []Cmder) {
defer wg.Done()
2020-02-14 15:30:07 +03:00
err := c._processPipelineNode(ctx, node, cmds, failedCmds)
if err == nil {
return
}
if attempt < c.opt.MaxRedirects {
2020-03-11 17:26:42 +03:00
if err := c.mapCmdsByNode(ctx, failedCmds, cmds); err != nil {
setCmdsErr(cmds, err)
}
} else {
setCmdsErr(cmds, err)
}
}(node, cmds)
}
2018-09-11 13:09:16 +03:00
wg.Wait()
if len(failedCmds.m) == 0 {
2016-12-13 18:28:39 +03:00
break
}
cmdsMap = failedCmds
}
2018-08-12 11:11:01 +03:00
return cmdsFirstErr(cmds)
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) mapCmdsByNode(ctx context.Context, cmdsMap *cmdsMap, cmds []Cmder) error {
state, err := c.state.Get(ctx)
2017-08-31 15:22:47 +03:00
if err != nil {
2018-09-11 13:09:16 +03:00
return err
2017-08-31 15:22:47 +03:00
}
if c.opt.ReadOnly && c.cmdsAreReadOnly(cmds) {
for _, cmd := range cmds {
slot := c.cmdSlot(cmd)
node, err := c.slotReadOnlyNode(state, slot)
if err != nil {
return err
}
cmdsMap.Add(node, cmd)
}
return nil
}
2016-12-13 18:28:39 +03:00
for _, cmd := range cmds {
slot := c.cmdSlot(cmd)
node, err := state.slotMasterNode(slot)
2016-12-13 18:28:39 +03:00
if err != nil {
2018-09-11 13:09:16 +03:00
return err
2016-12-13 18:28:39 +03:00
}
cmdsMap.Add(node, cmd)
2016-12-13 18:28:39 +03:00
}
2018-09-11 13:09:16 +03:00
return nil
2016-12-13 18:28:39 +03:00
}
func (c *ClusterClient) cmdsAreReadOnly(cmds []Cmder) bool {
for _, cmd := range cmds {
cmdInfo := c.cmdInfo(cmd.Name())
if cmdInfo == nil || !cmdInfo.ReadOnly {
return false
}
}
return true
}
2020-02-14 15:30:07 +03:00
func (c *ClusterClient) _processPipelineNode(
ctx context.Context, node *clusterNode, cmds []Cmder, failedCmds *cmdsMap,
) error {
return node.Client.hooks.processPipeline(ctx, cmds, func(ctx context.Context, cmds []Cmder) error {
return node.Client.withConn(ctx, func(ctx context.Context, cn *pool.Conn) error {
err := cn.WithWriter(ctx, c.opt.WriteTimeout, func(wr *proto.Writer) error {
return writeCmds(wr, cmds)
})
if err != nil {
return err
}
return cn.WithReader(ctx, c.opt.ReadTimeout, func(rd *proto.Reader) error {
2020-03-11 17:26:42 +03:00
return c.pipelineReadCmds(ctx, node, rd, cmds, failedCmds)
2020-02-14 15:30:07 +03:00
})
})
})
}
2016-12-13 18:28:39 +03:00
func (c *ClusterClient) pipelineReadCmds(
2020-03-11 17:26:42 +03:00
ctx context.Context,
node *clusterNode,
rd *proto.Reader,
cmds []Cmder,
failedCmds *cmdsMap,
2016-12-13 18:28:39 +03:00
) error {
for _, cmd := range cmds {
2018-08-15 09:38:58 +03:00
err := cmd.readReply(rd)
2016-12-13 18:28:39 +03:00
if err == nil {
continue
}
2020-03-11 17:26:42 +03:00
if c.checkMovedErr(ctx, cmd, err, failedCmds) {
2017-08-31 15:22:47 +03:00
continue
}
2016-12-13 18:28:39 +03:00
if c.opt.ReadOnly && isLoadingError(err) {
node.MarkAsFailing()
return err
2016-12-13 18:28:39 +03:00
}
if isRedisError(err) {
continue
2018-12-13 14:27:41 +03:00
}
return err
}
return nil
2016-12-13 18:28:39 +03:00
}
2017-08-31 15:22:47 +03:00
func (c *ClusterClient) checkMovedErr(
2020-03-11 17:26:42 +03:00
ctx context.Context, cmd Cmder, err error, failedCmds *cmdsMap,
2017-08-31 15:22:47 +03:00
) bool {
moved, ask, addr := isMovedError(err)
if !moved && !ask {
return false
}
node, err := c.nodes.Get(addr)
if err != nil {
return false
}
2017-08-31 15:22:47 +03:00
2016-12-13 18:28:39 +03:00
if moved {
2020-03-11 17:26:42 +03:00
c.state.LazyReload(ctx)
failedCmds.Add(node, cmd)
2017-08-31 15:22:47 +03:00
return true
2016-12-13 18:28:39 +03:00
}
2017-08-31 15:22:47 +03:00
2016-12-13 18:28:39 +03:00
if ask {
2020-03-11 17:26:42 +03:00
failedCmds.Add(node, NewCmd(ctx, "asking"), cmd)
2017-08-31 15:22:47 +03:00
return true
2016-12-13 18:28:39 +03:00
}
2017-08-31 15:22:47 +03:00
panic("not reached")
2016-12-13 18:28:39 +03:00
}
2016-12-16 15:19:53 +03:00
// TxPipeline acts like Pipeline, but wraps queued commands with MULTI/EXEC.
2017-05-02 18:00:53 +03:00
func (c *ClusterClient) TxPipeline() Pipeliner {
2016-12-13 18:28:39 +03:00
pipe := Pipeline{
2019-07-25 13:28:15 +03:00
ctx: c.ctx,
2018-01-20 13:26:33 +03:00
exec: c.processTxPipeline,
2016-12-13 18:28:39 +03:00
}
2019-05-31 17:03:20 +03:00
pipe.init()
2016-12-13 18:28:39 +03:00
return &pipe
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) TxPipelined(ctx context.Context, fn func(Pipeliner) error) ([]Cmder, error) {
return c.TxPipeline().Pipelined(ctx, fn)
2016-12-13 18:28:39 +03:00
}
2019-06-04 13:30:47 +03:00
func (c *ClusterClient) processTxPipeline(ctx context.Context, cmds []Cmder) error {
return c.hooks.processPipeline(ctx, cmds, c._processTxPipeline)
}
2019-06-04 13:30:47 +03:00
func (c *ClusterClient) _processTxPipeline(ctx context.Context, cmds []Cmder) error {
2020-03-11 17:26:42 +03:00
state, err := c.state.Get(ctx)
2016-12-13 18:28:39 +03:00
if err != nil {
setCmdsErr(cmds, err)
2016-12-13 18:28:39 +03:00
return err
}
2017-08-31 15:22:47 +03:00
cmdsMap := c.mapCmdsBySlot(cmds)
2016-12-13 18:28:39 +03:00
for slot, cmds := range cmdsMap {
2017-03-04 14:04:27 +03:00
node, err := state.slotMasterNode(slot)
2016-12-13 18:28:39 +03:00
if err != nil {
setCmdsErr(cmds, err)
continue
}
2017-08-31 15:22:47 +03:00
cmdsMap := map[*clusterNode][]Cmder{node: cmds}
2017-08-31 15:22:47 +03:00
for attempt := 0; attempt <= c.opt.MaxRedirects; attempt++ {
if attempt > 0 {
2019-07-30 12:13:00 +03:00
if err := internal.Sleep(ctx, c.retryBackoff(attempt)); err != nil {
setCmdsErr(cmds, err)
2019-07-30 12:13:00 +03:00
return err
}
2017-08-31 15:22:47 +03:00
}
2018-09-11 13:09:16 +03:00
failedCmds := newCmdsMap()
var wg sync.WaitGroup
2016-12-13 18:28:39 +03:00
for node, cmds := range cmdsMap {
2018-09-11 13:09:16 +03:00
wg.Add(1)
go func(node *clusterNode, cmds []Cmder) {
defer wg.Done()
2020-02-14 15:30:07 +03:00
err := c._processTxPipelineNode(ctx, node, cmds, failedCmds)
if err == nil {
return
}
if attempt < c.opt.MaxRedirects {
2020-03-11 17:26:42 +03:00
if err := c.mapCmdsByNode(ctx, failedCmds, cmds); err != nil {
2018-09-11 13:09:16 +03:00
setCmdsErr(cmds, err)
}
} else {
setCmdsErr(cmds, err)
}
2018-09-11 13:09:16 +03:00
}(node, cmds)
}
2018-09-11 13:09:16 +03:00
wg.Wait()
if len(failedCmds.m) == 0 {
2016-12-13 18:28:39 +03:00
break
}
2018-09-11 13:09:16 +03:00
cmdsMap = failedCmds.m
2016-12-13 18:28:39 +03:00
}
}
2018-08-12 11:11:01 +03:00
return cmdsFirstErr(cmds)
2016-12-13 18:28:39 +03:00
}
2017-08-31 15:22:47 +03:00
func (c *ClusterClient) mapCmdsBySlot(cmds []Cmder) map[int][]Cmder {
2016-12-13 18:28:39 +03:00
cmdsMap := make(map[int][]Cmder)
for _, cmd := range cmds {
2017-08-31 15:22:47 +03:00
slot := c.cmdSlot(cmd)
2016-12-13 18:28:39 +03:00
cmdsMap[slot] = append(cmdsMap[slot], cmd)
}
2017-08-31 15:22:47 +03:00
return cmdsMap
2016-12-13 18:28:39 +03:00
}
2020-02-14 15:30:07 +03:00
func (c *ClusterClient) _processTxPipelineNode(
ctx context.Context, node *clusterNode, cmds []Cmder, failedCmds *cmdsMap,
) error {
2020-02-14 16:37:35 +03:00
return node.Client.hooks.processTxPipeline(ctx, cmds, func(ctx context.Context, cmds []Cmder) error {
2020-02-14 15:30:07 +03:00
return node.Client.withConn(ctx, func(ctx context.Context, cn *pool.Conn) error {
err := cn.WithWriter(ctx, c.opt.WriteTimeout, func(wr *proto.Writer) error {
2020-02-14 16:37:35 +03:00
return writeCmds(wr, cmds)
2020-02-14 15:30:07 +03:00
})
if err != nil {
return err
}
return cn.WithReader(ctx, c.opt.ReadTimeout, func(rd *proto.Reader) error {
2020-02-14 16:37:35 +03:00
statusCmd := cmds[0].(*StatusCmd)
// Trim multi and exec.
cmds = cmds[1 : len(cmds)-1]
2020-03-11 17:26:42 +03:00
err := c.txPipelineReadQueued(ctx, rd, statusCmd, cmds, failedCmds)
2020-02-14 15:30:07 +03:00
if err != nil {
moved, ask, addr := isMovedError(err)
if moved || ask {
2020-03-11 17:26:42 +03:00
return c.cmdsMoved(ctx, cmds, moved, ask, addr, failedCmds)
2020-02-14 15:30:07 +03:00
}
return err
}
2020-02-14 16:37:35 +03:00
2020-02-14 15:30:07 +03:00
return pipelineReadCmds(rd, cmds)
})
})
})
}
2016-12-13 18:28:39 +03:00
func (c *ClusterClient) txPipelineReadQueued(
2020-03-11 17:26:42 +03:00
ctx context.Context,
rd *proto.Reader,
statusCmd *StatusCmd,
cmds []Cmder,
failedCmds *cmdsMap,
2016-12-13 18:28:39 +03:00
) error {
// Parse queued replies.
2018-08-15 09:38:58 +03:00
if err := statusCmd.readReply(rd); err != nil {
2017-08-31 15:22:47 +03:00
return err
2016-12-13 18:28:39 +03:00
}
for _, cmd := range cmds {
2018-08-15 09:38:58 +03:00
err := statusCmd.readReply(rd)
2020-03-11 17:26:42 +03:00
if err == nil || c.checkMovedErr(ctx, cmd, err, failedCmds) || isRedisError(err) {
2017-08-31 15:22:47 +03:00
continue
2016-12-13 18:28:39 +03:00
}
2017-08-31 15:22:47 +03:00
return err
}
2016-12-13 18:28:39 +03:00
// Parse number of replies.
2018-08-15 09:38:58 +03:00
line, err := rd.ReadLine()
2016-12-13 18:28:39 +03:00
if err != nil {
if err == Nil {
err = TxFailedErr
}
return err
}
switch line[0] {
case proto.ErrorReply:
return proto.ParseErrorReply(line)
2016-12-13 18:28:39 +03:00
case proto.ArrayReply:
// ok
default:
return fmt.Errorf("redis: expected '*', but got line %q", line)
}
return nil
}
func (c *ClusterClient) cmdsMoved(
2020-03-11 17:26:42 +03:00
ctx context.Context, cmds []Cmder,
moved, ask bool,
addr string,
failedCmds *cmdsMap,
) error {
node, err := c.nodes.Get(addr)
if err != nil {
2016-12-13 18:28:39 +03:00
return err
}
if moved {
2020-03-11 17:26:42 +03:00
c.state.LazyReload(ctx)
for _, cmd := range cmds {
failedCmds.Add(node, cmd)
}
return nil
}
if ask {
for _, cmd := range cmds {
2020-03-11 17:26:42 +03:00
failedCmds.Add(node, NewCmd(ctx, "asking"), cmd)
}
return nil
}
2017-08-31 15:22:47 +03:00
return nil
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) Watch(ctx context.Context, fn func(*Tx) error, keys ...string) error {
if len(keys) == 0 {
return fmt.Errorf("redis: Watch requires at least one key")
}
slot := hashtag.Slot(keys[0])
for _, key := range keys[1:] {
if hashtag.Slot(key) != slot {
err := fmt.Errorf("redis: Watch requires all keys to be in the same slot")
return err
}
}
2020-03-11 17:26:42 +03:00
node, err := c.slotMasterNode(ctx, slot)
if err != nil {
return err
}
for attempt := 0; attempt <= c.opt.MaxRedirects; attempt++ {
if attempt > 0 {
2019-07-30 12:13:00 +03:00
if err := internal.Sleep(ctx, c.retryBackoff(attempt)); err != nil {
return err
}
}
2020-03-11 17:26:42 +03:00
err = node.Client.Watch(ctx, fn, keys...)
if err == nil {
break
}
moved, ask, addr := isMovedError(err)
if moved || ask {
2019-06-29 10:28:33 +03:00
node, err = c.nodes.Get(addr)
if err != nil {
return err
}
continue
}
2020-06-30 11:13:15 +03:00
if isReadOnly := isReadOnlyError(err); isReadOnly || err == pool.ErrClosed {
if isReadOnly {
c.state.LazyReload(ctx)
}
2020-03-11 17:26:42 +03:00
node, err = c.slotMasterNode(ctx, slot)
if err != nil {
return err
}
continue
}
2020-07-24 14:57:12 +03:00
if shouldRetry(err, true) {
continue
}
return err
}
return err
}
func (c *ClusterClient) pubSub() *PubSub {
2017-07-09 10:07:20 +03:00
var node *clusterNode
2018-07-23 15:55:13 +03:00
pubsub := &PubSub{
opt: c.opt.clientOptions(),
2017-07-09 10:07:20 +03:00
2020-03-11 17:26:42 +03:00
newConn: func(ctx context.Context, channels []string) (*pool.Conn, error) {
if node != nil {
panic("node != nil")
}
2017-07-09 10:07:20 +03:00
var err error
if len(channels) > 0 {
slot := hashtag.Slot(channels[0])
2020-03-11 17:26:42 +03:00
node, err = c.slotMasterNode(ctx, slot)
} else {
node, err = c.nodes.Random()
}
if err != nil {
return nil, err
2017-07-09 10:07:20 +03:00
}
2019-06-14 16:00:03 +03:00
cn, err := node.Client.newConn(context.TODO())
if err != nil {
2019-04-18 19:06:16 +03:00
node = nil
return nil, err
}
return cn, nil
2017-07-09 10:07:20 +03:00
},
closeConn: func(cn *pool.Conn) error {
err := node.Client.connPool.CloseConn(cn)
node = nil
return err
2017-07-09 10:07:20 +03:00
},
}
2018-07-23 15:55:13 +03:00
pubsub.init()
2018-07-23 15:55:13 +03:00
return pubsub
2017-07-09 10:07:20 +03:00
}
// Subscribe subscribes the client to the specified channels.
// Channels can be omitted to create empty subscription.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) Subscribe(ctx context.Context, channels ...string) *PubSub {
pubsub := c.pubSub()
2017-07-09 10:07:20 +03:00
if len(channels) > 0 {
2020-03-11 17:26:42 +03:00
_ = pubsub.Subscribe(ctx, channels...)
2017-07-09 10:07:20 +03:00
}
return pubsub
}
// PSubscribe subscribes the client to the given patterns.
// Patterns can be omitted to create empty subscription.
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) PSubscribe(ctx context.Context, channels ...string) *PubSub {
pubsub := c.pubSub()
2017-07-09 10:07:20 +03:00
if len(channels) > 0 {
2020-03-11 17:26:42 +03:00
_ = pubsub.PSubscribe(ctx, channels...)
2017-07-09 10:07:20 +03:00
}
return pubsub
}
func (c *ClusterClient) retryBackoff(attempt int) time.Duration {
return internal.RetryBackoff(attempt, c.opt.MinRetryBackoff, c.opt.MaxRetryBackoff)
}
func (c *ClusterClient) cmdsInfo() (map[string]*CommandInfo, error) {
2020-07-19 09:49:00 +03:00
// Try 3 random nodes.
const nodeLimit = 3
addrs, err := c.nodes.Addrs()
if err != nil {
return nil, err
}
var firstErr error
2020-07-19 09:49:00 +03:00
perm := rand.Perm(len(addrs))
if len(perm) > nodeLimit {
perm = perm[:nodeLimit]
}
for _, idx := range perm {
addr := addrs[idx]
node, err := c.nodes.Get(addr)
if err != nil {
2020-07-19 09:49:00 +03:00
if firstErr == nil {
firstErr = err
}
continue
}
2020-07-19 09:49:00 +03:00
info, err := node.Client.Command(c.ctx).Result()
if err == nil {
return info, nil
}
if firstErr == nil {
firstErr = err
}
}
2020-07-19 09:49:00 +03:00
if firstErr == nil {
panic("not reached")
}
return nil, firstErr
}
func (c *ClusterClient) cmdInfo(name string) *CommandInfo {
cmdsInfo, err := c.cmdsInfoCache.Get()
if err != nil {
return nil
}
info := cmdsInfo[name]
if info == nil {
internal.Logger.Printf(c.Context(), "info for cmd=%s not found", name)
}
return info
}
func (c *ClusterClient) cmdSlot(cmd Cmder) int {
args := cmd.Args()
if args[0] == "cluster" && args[1] == "getkeysinslot" {
return args[2].(int)
}
cmdInfo := c.cmdInfo(cmd.Name())
return cmdSlot(cmd, cmdFirstKeyPos(cmd, cmdInfo))
}
func cmdSlot(cmd Cmder, pos int) int {
if pos == 0 {
return hashtag.RandomSlot()
}
firstKey := cmd.stringArg(pos)
return hashtag.Slot(firstKey)
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) cmdNode(
ctx context.Context,
cmdInfo *CommandInfo,
slot int,
) (*clusterNode, error) {
state, err := c.state.Get(ctx)
if err != nil {
return nil, err
}
if c.opt.ReadOnly && cmdInfo != nil && cmdInfo.ReadOnly {
return c.slotReadOnlyNode(state, slot)
}
return state.slotMasterNode(slot)
}
func (c *clusterClient) slotReadOnlyNode(state *clusterState, slot int) (*clusterNode, error) {
if c.opt.RouteByLatency {
return state.slotClosestNode(slot)
}
if c.opt.RouteRandomly {
return state.slotRandomNode(slot)
}
return state.slotSlaveNode(slot)
}
2020-03-11 17:26:42 +03:00
func (c *ClusterClient) slotMasterNode(ctx context.Context, slot int) (*clusterNode, error) {
state, err := c.state.Get(ctx)
if err != nil {
return nil, err
}
return state.slotMasterNode(slot)
}
2018-05-17 16:09:56 +03:00
func appendUniqueNode(nodes []*clusterNode, node *clusterNode) []*clusterNode {
2017-07-09 13:10:07 +03:00
for _, n := range nodes {
if n == node {
return nodes
}
}
return append(nodes, node)
}
func appendIfNotExists(ss []string, es ...string) []string {
loop:
for _, e := range es {
for _, s := range ss {
if s == e {
continue loop
}
}
ss = append(ss, e)
}
return ss
}
//------------------------------------------------------------------------------
type cmdsMap struct {
mu sync.Mutex
m map[*clusterNode][]Cmder
}
func newCmdsMap() *cmdsMap {
return &cmdsMap{
m: make(map[*clusterNode][]Cmder),
}
}
func (m *cmdsMap) Add(node *clusterNode, cmds ...Cmder) {
m.mu.Lock()
m.m[node] = append(m.m[node], cmds...)
m.mu.Unlock()
}