2019-04-08 14:35:15 +05:30
|
|
|
package redis
|
|
|
|
|
|
|
|
import (
|
2020-09-28 02:39:46 +05:30
|
|
|
"context"
|
2019-04-08 14:35:15 +05:30
|
|
|
"errors"
|
|
|
|
"fmt"
|
2020-09-28 02:39:46 +05:30
|
|
|
"strings"
|
2019-04-08 14:35:15 +05:30
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
"github.com/go-redis/redis/v8/internal"
|
|
|
|
"github.com/go-redis/redis/v8/internal/pool"
|
|
|
|
"github.com/go-redis/redis/v8/internal/proto"
|
2019-04-08 14:35:15 +05:30
|
|
|
)
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
const (
|
|
|
|
pingTimeout = time.Second
|
|
|
|
chanSendTimeout = time.Minute
|
|
|
|
)
|
2020-09-28 02:39:46 +05:30
|
|
|
|
2019-04-08 14:35:15 +05:30
|
|
|
var errPingTimeout = errors.New("redis: ping timeout")
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
// PubSub implements Pub/Sub commands as described in
|
2019-04-08 14:35:15 +05:30
|
|
|
// http://redis.io/topics/pubsub. Message receiving is NOT safe
|
|
|
|
// for concurrent use by multiple goroutines.
|
|
|
|
//
|
|
|
|
// PubSub automatically reconnects to Redis Server and resubscribes
|
|
|
|
// to the channels in case of network errors.
|
|
|
|
type PubSub struct {
|
|
|
|
opt *Options
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
newConn func(ctx context.Context, channels []string) (*pool.Conn, error)
|
2019-04-08 14:35:15 +05:30
|
|
|
closeConn func(*pool.Conn) error
|
|
|
|
|
|
|
|
mu sync.Mutex
|
|
|
|
cn *pool.Conn
|
|
|
|
channels map[string]struct{}
|
|
|
|
patterns map[string]struct{}
|
2020-09-28 02:39:46 +05:30
|
|
|
|
|
|
|
closed bool
|
|
|
|
exit chan struct{}
|
2019-04-08 14:35:15 +05:30
|
|
|
|
|
|
|
cmd *Cmd
|
|
|
|
|
|
|
|
chOnce sync.Once
|
2020-09-28 02:39:46 +05:30
|
|
|
msgCh chan *Message
|
|
|
|
allCh chan interface{}
|
2019-04-08 14:35:15 +05:30
|
|
|
ping chan struct{}
|
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
func (c *PubSub) String() string {
|
|
|
|
channels := mapKeys(c.channels)
|
|
|
|
channels = append(channels, mapKeys(c.patterns)...)
|
|
|
|
return fmt.Sprintf("PubSub(%s)", strings.Join(channels, ", "))
|
|
|
|
}
|
|
|
|
|
2019-04-08 14:35:15 +05:30
|
|
|
func (c *PubSub) init() {
|
|
|
|
c.exit = make(chan struct{})
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) connWithLock(ctx context.Context) (*pool.Conn, error) {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
2021-02-11 02:58:32 +05:30
|
|
|
cn, err := c.conn(ctx, nil)
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Unlock()
|
|
|
|
return cn, err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) conn(ctx context.Context, newChannels []string) (*pool.Conn, error) {
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.closed {
|
|
|
|
return nil, pool.ErrClosed
|
|
|
|
}
|
|
|
|
if c.cn != nil {
|
|
|
|
return c.cn, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
channels := mapKeys(c.channels)
|
|
|
|
channels = append(channels, newChannels...)
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
cn, err := c.newConn(ctx, channels)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
if err := c.resubscribe(ctx, cn); err != nil {
|
2019-04-08 14:35:15 +05:30
|
|
|
_ = c.closeConn(cn)
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
c.cn = cn
|
|
|
|
return cn, nil
|
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
func (c *PubSub) writeCmd(ctx context.Context, cn *pool.Conn, cmd Cmder) error {
|
|
|
|
return cn.WithWriter(ctx, c.opt.WriteTimeout, func(wr *proto.Writer) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
return writeCmd(wr, cmd)
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) resubscribe(ctx context.Context, cn *pool.Conn) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
var firstErr error
|
|
|
|
|
|
|
|
if len(c.channels) > 0 {
|
2021-02-11 02:58:32 +05:30
|
|
|
firstErr = c._subscribe(ctx, cn, "subscribe", mapKeys(c.channels))
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
|
|
|
if len(c.patterns) > 0 {
|
2021-02-11 02:58:32 +05:30
|
|
|
err := c._subscribe(ctx, cn, "psubscribe", mapKeys(c.patterns))
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil && firstErr == nil {
|
|
|
|
firstErr = err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return firstErr
|
|
|
|
}
|
|
|
|
|
|
|
|
func mapKeys(m map[string]struct{}) []string {
|
|
|
|
s := make([]string, len(m))
|
|
|
|
i := 0
|
|
|
|
for k := range m {
|
|
|
|
s[i] = k
|
|
|
|
i++
|
|
|
|
}
|
|
|
|
return s
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *PubSub) _subscribe(
|
2021-02-11 02:58:32 +05:30
|
|
|
ctx context.Context, cn *pool.Conn, redisCmd string, channels []string,
|
2019-04-08 14:35:15 +05:30
|
|
|
) error {
|
|
|
|
args := make([]interface{}, 0, 1+len(channels))
|
|
|
|
args = append(args, redisCmd)
|
|
|
|
for _, channel := range channels {
|
|
|
|
args = append(args, channel)
|
|
|
|
}
|
2021-02-11 02:58:32 +05:30
|
|
|
cmd := NewSliceCmd(ctx, args...)
|
|
|
|
return c.writeCmd(ctx, cn, cmd)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) releaseConnWithLock(
|
|
|
|
ctx context.Context,
|
|
|
|
cn *pool.Conn,
|
|
|
|
err error,
|
|
|
|
allowTimeout bool,
|
|
|
|
) {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
2021-02-11 02:58:32 +05:30
|
|
|
c.releaseConn(ctx, cn, err, allowTimeout)
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Unlock()
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) releaseConn(ctx context.Context, cn *pool.Conn, err error, allowTimeout bool) {
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.cn != cn {
|
|
|
|
return
|
|
|
|
}
|
2020-09-28 02:39:46 +05:30
|
|
|
if isBadConn(err, allowTimeout) {
|
2021-02-11 02:58:32 +05:30
|
|
|
c.reconnect(ctx, err)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) reconnect(ctx context.Context, reason error) {
|
2020-09-28 02:39:46 +05:30
|
|
|
_ = c.closeTheCn(reason)
|
2021-02-11 02:58:32 +05:30
|
|
|
_, _ = c.conn(ctx, nil)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
func (c *PubSub) closeTheCn(reason error) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.cn == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
if !c.closed {
|
2021-02-11 02:58:32 +05:30
|
|
|
internal.Logger.Printf(c.getContext(), "redis: discarding bad PubSub connection: %s", reason)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
err := c.closeConn(c.cn)
|
|
|
|
c.cn = nil
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *PubSub) Close() error {
|
|
|
|
c.mu.Lock()
|
|
|
|
defer c.mu.Unlock()
|
|
|
|
|
|
|
|
if c.closed {
|
|
|
|
return pool.ErrClosed
|
|
|
|
}
|
|
|
|
c.closed = true
|
|
|
|
close(c.exit)
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
return c.closeTheCn(pool.ErrClosed)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
|
|
|
// Subscribe the client to the specified channels. It returns
|
|
|
|
// empty subscription if there are no channels.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) Subscribe(ctx context.Context, channels ...string) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
|
|
|
defer c.mu.Unlock()
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
err := c.subscribe(ctx, "subscribe", channels...)
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.channels == nil {
|
|
|
|
c.channels = make(map[string]struct{})
|
|
|
|
}
|
|
|
|
for _, s := range channels {
|
|
|
|
c.channels[s] = struct{}{}
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// PSubscribe the client to the given patterns. It returns
|
|
|
|
// empty subscription if there are no patterns.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) PSubscribe(ctx context.Context, patterns ...string) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
|
|
|
defer c.mu.Unlock()
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
err := c.subscribe(ctx, "psubscribe", patterns...)
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.patterns == nil {
|
|
|
|
c.patterns = make(map[string]struct{})
|
|
|
|
}
|
|
|
|
for _, s := range patterns {
|
|
|
|
c.patterns[s] = struct{}{}
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Unsubscribe the client from the given channels, or from all of
|
|
|
|
// them if none is given.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) Unsubscribe(ctx context.Context, channels ...string) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
|
|
|
defer c.mu.Unlock()
|
|
|
|
|
|
|
|
for _, channel := range channels {
|
|
|
|
delete(c.channels, channel)
|
|
|
|
}
|
2021-02-11 02:58:32 +05:30
|
|
|
err := c.subscribe(ctx, "unsubscribe", channels...)
|
2019-04-08 14:35:15 +05:30
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// PUnsubscribe the client from the given patterns, or from all of
|
|
|
|
// them if none is given.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) PUnsubscribe(ctx context.Context, patterns ...string) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
c.mu.Lock()
|
|
|
|
defer c.mu.Unlock()
|
|
|
|
|
|
|
|
for _, pattern := range patterns {
|
|
|
|
delete(c.patterns, pattern)
|
|
|
|
}
|
2021-02-11 02:58:32 +05:30
|
|
|
err := c.subscribe(ctx, "punsubscribe", patterns...)
|
2019-04-08 14:35:15 +05:30
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) subscribe(ctx context.Context, redisCmd string, channels ...string) error {
|
|
|
|
cn, err := c.conn(ctx, channels)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
err = c._subscribe(ctx, cn, redisCmd, channels)
|
|
|
|
c.releaseConn(ctx, cn, err, false)
|
2019-04-08 14:35:15 +05:30
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) Ping(ctx context.Context, payload ...string) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
args := []interface{}{"ping"}
|
|
|
|
if len(payload) == 1 {
|
|
|
|
args = append(args, payload[0])
|
|
|
|
}
|
2021-02-11 02:58:32 +05:30
|
|
|
cmd := NewCmd(ctx, args...)
|
2019-04-08 14:35:15 +05:30
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
cn, err := c.connWithLock(ctx)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
err = c.writeCmd(ctx, cn, cmd)
|
|
|
|
c.releaseConnWithLock(ctx, cn, err, false)
|
2019-04-08 14:35:15 +05:30
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Subscription received after a successful subscription to channel.
|
|
|
|
type Subscription struct {
|
|
|
|
// Can be "subscribe", "unsubscribe", "psubscribe" or "punsubscribe".
|
|
|
|
Kind string
|
|
|
|
// Channel name we have subscribed to.
|
|
|
|
Channel string
|
|
|
|
// Number of channels we are currently subscribed to.
|
|
|
|
Count int
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Subscription) String() string {
|
|
|
|
return fmt.Sprintf("%s: %s", m.Kind, m.Channel)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Message received as result of a PUBLISH command issued by another client.
|
|
|
|
type Message struct {
|
2021-02-11 02:58:32 +05:30
|
|
|
Channel string
|
|
|
|
Pattern string
|
|
|
|
Payload string
|
|
|
|
PayloadSlice []string
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Message) String() string {
|
|
|
|
return fmt.Sprintf("Message<%s: %s>", m.Channel, m.Payload)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Pong received as result of a PING command issued by another client.
|
|
|
|
type Pong struct {
|
|
|
|
Payload string
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *Pong) String() string {
|
|
|
|
if p.Payload != "" {
|
|
|
|
return fmt.Sprintf("Pong<%s>", p.Payload)
|
|
|
|
}
|
|
|
|
return "Pong"
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *PubSub) newMessage(reply interface{}) (interface{}, error) {
|
|
|
|
switch reply := reply.(type) {
|
|
|
|
case string:
|
|
|
|
return &Pong{
|
|
|
|
Payload: reply,
|
|
|
|
}, nil
|
|
|
|
case []interface{}:
|
|
|
|
switch kind := reply[0].(string); kind {
|
|
|
|
case "subscribe", "unsubscribe", "psubscribe", "punsubscribe":
|
2020-09-28 02:39:46 +05:30
|
|
|
// Can be nil in case of "unsubscribe".
|
|
|
|
channel, _ := reply[1].(string)
|
2019-04-08 14:35:15 +05:30
|
|
|
return &Subscription{
|
|
|
|
Kind: kind,
|
2020-09-28 02:39:46 +05:30
|
|
|
Channel: channel,
|
2019-04-08 14:35:15 +05:30
|
|
|
Count: int(reply[2].(int64)),
|
|
|
|
}, nil
|
|
|
|
case "message":
|
2021-02-11 02:58:32 +05:30
|
|
|
switch payload := reply[2].(type) {
|
|
|
|
case string:
|
|
|
|
return &Message{
|
|
|
|
Channel: reply[1].(string),
|
|
|
|
Payload: payload,
|
|
|
|
}, nil
|
|
|
|
case []interface{}:
|
|
|
|
ss := make([]string, len(payload))
|
|
|
|
for i, s := range payload {
|
|
|
|
ss[i] = s.(string)
|
|
|
|
}
|
|
|
|
return &Message{
|
|
|
|
Channel: reply[1].(string),
|
|
|
|
PayloadSlice: ss,
|
|
|
|
}, nil
|
|
|
|
default:
|
|
|
|
return nil, fmt.Errorf("redis: unsupported pubsub message payload: %T", payload)
|
|
|
|
}
|
2019-04-08 14:35:15 +05:30
|
|
|
case "pmessage":
|
|
|
|
return &Message{
|
|
|
|
Pattern: reply[1].(string),
|
|
|
|
Channel: reply[2].(string),
|
|
|
|
Payload: reply[3].(string),
|
|
|
|
}, nil
|
|
|
|
case "pong":
|
|
|
|
return &Pong{
|
|
|
|
Payload: reply[1].(string),
|
|
|
|
}, nil
|
|
|
|
default:
|
|
|
|
return nil, fmt.Errorf("redis: unsupported pubsub message: %q", kind)
|
|
|
|
}
|
|
|
|
default:
|
|
|
|
return nil, fmt.Errorf("redis: unsupported pubsub message: %#v", reply)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// ReceiveTimeout acts like Receive but returns an error if message
|
|
|
|
// is not received in time. This is low-level API and in most cases
|
|
|
|
// Channel should be used instead.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) ReceiveTimeout(ctx context.Context, timeout time.Duration) (interface{}, error) {
|
2019-04-08 14:35:15 +05:30
|
|
|
if c.cmd == nil {
|
2021-02-11 02:58:32 +05:30
|
|
|
c.cmd = NewCmd(ctx)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
cn, err := c.connWithLock(ctx)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
err = cn.WithReader(ctx, timeout, func(rd *proto.Reader) error {
|
2019-04-08 14:35:15 +05:30
|
|
|
return c.cmd.readReply(rd)
|
|
|
|
})
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
c.releaseConnWithLock(ctx, cn, err, timeout > 0)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return c.newMessage(c.cmd.Val())
|
|
|
|
}
|
|
|
|
|
|
|
|
// Receive returns a message as a Subscription, Message, Pong or error.
|
|
|
|
// See PubSub example for details. This is low-level API and in most cases
|
|
|
|
// Channel should be used instead.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) Receive(ctx context.Context) (interface{}, error) {
|
|
|
|
return c.ReceiveTimeout(ctx, 0)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
|
|
|
// ReceiveMessage returns a Message or error ignoring Subscription and Pong
|
|
|
|
// messages. This is low-level API and in most cases Channel should be used
|
|
|
|
// instead.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) ReceiveMessage(ctx context.Context) (*Message, error) {
|
2019-04-08 14:35:15 +05:30
|
|
|
for {
|
2021-02-11 02:58:32 +05:30
|
|
|
msg, err := c.Receive(ctx)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
switch msg := msg.(type) {
|
|
|
|
case *Subscription:
|
|
|
|
// Ignore.
|
|
|
|
case *Pong:
|
|
|
|
// Ignore.
|
|
|
|
case *Message:
|
|
|
|
return msg, nil
|
|
|
|
default:
|
|
|
|
err := fmt.Errorf("redis: unknown message: %T", msg)
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Channel returns a Go channel for concurrently receiving messages.
|
2020-09-28 02:39:46 +05:30
|
|
|
// The channel is closed together with the PubSub. If the Go channel
|
|
|
|
// is blocked full for 30 seconds the message is dropped.
|
|
|
|
// Receive* APIs can not be used after channel is created.
|
|
|
|
//
|
|
|
|
// go-redis periodically sends ping messages to test connection health
|
|
|
|
// and re-subscribes if ping can not not received for 30 seconds.
|
2019-04-08 14:35:15 +05:30
|
|
|
func (c *PubSub) Channel() <-chan *Message {
|
2020-09-28 02:39:46 +05:30
|
|
|
return c.ChannelSize(100)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
// ChannelSize is like Channel, but creates a Go channel
|
|
|
|
// with specified buffer size.
|
|
|
|
func (c *PubSub) ChannelSize(size int) <-chan *Message {
|
|
|
|
c.chOnce.Do(func() {
|
|
|
|
c.initPing()
|
|
|
|
c.initMsgChan(size)
|
|
|
|
})
|
|
|
|
if c.msgCh == nil {
|
|
|
|
err := fmt.Errorf("redis: Channel can't be called after ChannelWithSubscriptions")
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
if cap(c.msgCh) != size {
|
|
|
|
err := fmt.Errorf("redis: PubSub.Channel size can not be changed once created")
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
return c.msgCh
|
|
|
|
}
|
|
|
|
|
|
|
|
// ChannelWithSubscriptions is like Channel, but message type can be either
|
|
|
|
// *Subscription or *Message. Subscription messages can be used to detect
|
|
|
|
// reconnections.
|
|
|
|
//
|
|
|
|
// ChannelWithSubscriptions can not be used together with Channel or ChannelSize.
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) ChannelWithSubscriptions(ctx context.Context, size int) <-chan interface{} {
|
2020-09-28 02:39:46 +05:30
|
|
|
c.chOnce.Do(func() {
|
|
|
|
c.initPing()
|
|
|
|
c.initAllChan(size)
|
|
|
|
})
|
|
|
|
if c.allCh == nil {
|
|
|
|
err := fmt.Errorf("redis: ChannelWithSubscriptions can't be called after Channel")
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
if cap(c.allCh) != size {
|
|
|
|
err := fmt.Errorf("redis: PubSub.Channel size can not be changed once created")
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
return c.allCh
|
|
|
|
}
|
|
|
|
|
2021-02-11 02:58:32 +05:30
|
|
|
func (c *PubSub) getContext() context.Context {
|
|
|
|
if c.cmd != nil {
|
|
|
|
return c.cmd.ctx
|
|
|
|
}
|
|
|
|
return context.Background()
|
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
func (c *PubSub) initPing() {
|
2021-02-11 02:58:32 +05:30
|
|
|
ctx := context.TODO()
|
2020-09-28 02:39:46 +05:30
|
|
|
c.ping = make(chan struct{}, 1)
|
|
|
|
go func() {
|
2021-02-11 02:58:32 +05:30
|
|
|
timer := time.NewTimer(time.Minute)
|
2020-09-28 02:39:46 +05:30
|
|
|
timer.Stop()
|
|
|
|
|
|
|
|
healthy := true
|
|
|
|
for {
|
|
|
|
timer.Reset(pingTimeout)
|
|
|
|
select {
|
|
|
|
case <-c.ping:
|
|
|
|
healthy = true
|
|
|
|
if !timer.Stop() {
|
|
|
|
<-timer.C
|
|
|
|
}
|
|
|
|
case <-timer.C:
|
2021-02-11 02:58:32 +05:30
|
|
|
pingErr := c.Ping(ctx)
|
2020-09-28 02:39:46 +05:30
|
|
|
if healthy {
|
|
|
|
healthy = false
|
|
|
|
} else {
|
|
|
|
if pingErr == nil {
|
|
|
|
pingErr = errPingTimeout
|
|
|
|
}
|
|
|
|
c.mu.Lock()
|
2021-02-11 02:58:32 +05:30
|
|
|
c.reconnect(ctx, pingErr)
|
2020-09-28 02:39:46 +05:30
|
|
|
healthy = true
|
|
|
|
c.mu.Unlock()
|
|
|
|
}
|
|
|
|
case <-c.exit:
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
}
|
2019-04-08 14:35:15 +05:30
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
// initMsgChan must be in sync with initAllChan.
|
|
|
|
func (c *PubSub) initMsgChan(size int) {
|
2021-02-11 02:58:32 +05:30
|
|
|
ctx := context.TODO()
|
2020-09-28 02:39:46 +05:30
|
|
|
c.msgCh = make(chan *Message, size)
|
2019-04-08 14:35:15 +05:30
|
|
|
go func() {
|
2021-02-11 02:58:32 +05:30
|
|
|
timer := time.NewTimer(time.Minute)
|
2020-09-28 02:39:46 +05:30
|
|
|
timer.Stop()
|
|
|
|
|
2019-04-08 14:35:15 +05:30
|
|
|
var errCount int
|
|
|
|
for {
|
2021-02-11 02:58:32 +05:30
|
|
|
msg, err := c.Receive(ctx)
|
2019-04-08 14:35:15 +05:30
|
|
|
if err != nil {
|
|
|
|
if err == pool.ErrClosed {
|
2020-09-28 02:39:46 +05:30
|
|
|
close(c.msgCh)
|
2019-04-08 14:35:15 +05:30
|
|
|
return
|
|
|
|
}
|
|
|
|
if errCount > 0 {
|
2021-02-11 02:58:32 +05:30
|
|
|
time.Sleep(100 * time.Millisecond)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
errCount++
|
|
|
|
continue
|
|
|
|
}
|
2020-09-28 02:39:46 +05:30
|
|
|
|
2019-04-08 14:35:15 +05:30
|
|
|
errCount = 0
|
|
|
|
|
|
|
|
// Any message is as good as a ping.
|
|
|
|
select {
|
|
|
|
case c.ping <- struct{}{}:
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
|
|
|
|
switch msg := msg.(type) {
|
|
|
|
case *Subscription:
|
|
|
|
// Ignore.
|
|
|
|
case *Pong:
|
|
|
|
// Ignore.
|
|
|
|
case *Message:
|
2021-02-11 02:58:32 +05:30
|
|
|
timer.Reset(chanSendTimeout)
|
2020-09-28 02:39:46 +05:30
|
|
|
select {
|
|
|
|
case c.msgCh <- msg:
|
|
|
|
if !timer.Stop() {
|
|
|
|
<-timer.C
|
|
|
|
}
|
|
|
|
case <-timer.C:
|
|
|
|
internal.Logger.Printf(
|
2021-02-11 02:58:32 +05:30
|
|
|
c.getContext(),
|
|
|
|
"redis: %s channel is full for %s (message is dropped)",
|
|
|
|
c,
|
|
|
|
chanSendTimeout,
|
|
|
|
)
|
2020-09-28 02:39:46 +05:30
|
|
|
}
|
2019-04-08 14:35:15 +05:30
|
|
|
default:
|
2021-02-11 02:58:32 +05:30
|
|
|
internal.Logger.Printf(c.getContext(), "redis: unknown message type: %T", msg)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
2020-09-28 02:39:46 +05:30
|
|
|
}
|
2019-04-08 14:35:15 +05:30
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
// initAllChan must be in sync with initMsgChan.
|
|
|
|
func (c *PubSub) initAllChan(size int) {
|
2021-02-11 02:58:32 +05:30
|
|
|
ctx := context.TODO()
|
2020-09-28 02:39:46 +05:30
|
|
|
c.allCh = make(chan interface{}, size)
|
2019-04-08 14:35:15 +05:30
|
|
|
go func() {
|
2020-09-28 02:39:46 +05:30
|
|
|
timer := time.NewTimer(pingTimeout)
|
2019-04-08 14:35:15 +05:30
|
|
|
timer.Stop()
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
var errCount int
|
2019-04-08 14:35:15 +05:30
|
|
|
for {
|
2021-02-11 02:58:32 +05:30
|
|
|
msg, err := c.Receive(ctx)
|
2020-09-28 02:39:46 +05:30
|
|
|
if err != nil {
|
|
|
|
if err == pool.ErrClosed {
|
|
|
|
close(c.allCh)
|
|
|
|
return
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
2020-09-28 02:39:46 +05:30
|
|
|
if errCount > 0 {
|
2021-02-11 02:58:32 +05:30
|
|
|
time.Sleep(100 * time.Millisecond)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
2020-09-28 02:39:46 +05:30
|
|
|
errCount++
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
errCount = 0
|
|
|
|
|
|
|
|
// Any message is as good as a ping.
|
|
|
|
select {
|
|
|
|
case c.ping <- struct{}{}:
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
|
|
|
|
switch msg := msg.(type) {
|
|
|
|
case *Subscription:
|
|
|
|
c.sendMessage(msg, timer)
|
|
|
|
case *Pong:
|
|
|
|
// Ignore.
|
|
|
|
case *Message:
|
|
|
|
c.sendMessage(msg, timer)
|
|
|
|
default:
|
2021-02-11 02:58:32 +05:30
|
|
|
internal.Logger.Printf(c.getContext(), "redis: unknown message type: %T", msg)
|
2019-04-08 14:35:15 +05:30
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
}
|
|
|
|
|
2020-09-28 02:39:46 +05:30
|
|
|
func (c *PubSub) sendMessage(msg interface{}, timer *time.Timer) {
|
|
|
|
timer.Reset(pingTimeout)
|
|
|
|
select {
|
|
|
|
case c.allCh <- msg:
|
|
|
|
if !timer.Stop() {
|
|
|
|
<-timer.C
|
|
|
|
}
|
|
|
|
case <-timer.C:
|
|
|
|
internal.Logger.Printf(
|
2021-02-11 02:58:32 +05:30
|
|
|
c.getContext(),
|
2020-09-28 02:39:46 +05:30
|
|
|
"redis: %s channel is full for %s (message is dropped)", c, pingTimeout)
|
|
|
|
}
|
|
|
|
}
|