redis/pubsub.go

453 lines
9.1 KiB
Go
Raw Normal View History

2012-07-25 17:00:50 +04:00
package redis
import (
"fmt"
"sync"
2014-05-11 11:42:40 +04:00
"time"
2017-02-18 17:42:34 +03:00
"github.com/go-redis/redis/internal"
"github.com/go-redis/redis/internal/pool"
2012-07-25 17:00:50 +04:00
)
2015-05-23 14:15:05 +03:00
// PubSub implements Pub/Sub commands as described in
2018-07-23 15:55:13 +03:00
// http://redis.io/topics/pubsub. Message receiving is NOT safe
// for concurrent use by multiple goroutines.
2017-05-11 17:02:26 +03:00
//
2018-07-23 15:55:13 +03:00
// PubSub automatically reconnects to Redis Server and resubscribes
// to the channels in case of network errors.
2014-05-11 11:42:40 +04:00
type PubSub struct {
2017-07-09 10:07:20 +03:00
opt *Options
newConn func([]string) (*pool.Conn, error)
closeConn func(*pool.Conn) error
mu sync.Mutex
cn *pool.Conn
channels map[string]struct{}
patterns map[string]struct{}
closed bool
2018-07-23 15:55:13 +03:00
exit chan struct{}
2017-04-24 12:43:15 +03:00
cmd *Cmd
2017-10-30 13:09:57 +03:00
2018-07-23 15:55:13 +03:00
pingOnce sync.Once
ping chan struct{}
2017-10-30 13:09:57 +03:00
chOnce sync.Once
ch chan *Message
2016-09-29 15:07:04 +03:00
}
2018-07-23 15:55:13 +03:00
func (c *PubSub) init() {
c.exit = make(chan struct{})
}
2017-06-29 17:05:08 +03:00
func (c *PubSub) conn() (*pool.Conn, error) {
2017-04-24 12:43:15 +03:00
c.mu.Lock()
2017-07-09 10:07:20 +03:00
cn, err := c._conn(nil)
2017-06-29 17:05:08 +03:00
c.mu.Unlock()
return cn, err
}
2017-04-24 12:43:15 +03:00
2017-07-09 10:07:20 +03:00
func (c *PubSub) _conn(channels []string) (*pool.Conn, error) {
2017-04-24 12:43:15 +03:00
if c.closed {
2017-06-29 17:05:08 +03:00
return nil, pool.ErrClosed
2017-04-24 12:43:15 +03:00
}
if c.cn != nil {
2017-06-29 17:05:08 +03:00
return c.cn, nil
2017-04-24 12:43:15 +03:00
}
2017-07-09 10:07:20 +03:00
cn, err := c.newConn(channels)
2016-09-29 15:07:04 +03:00
if err != nil {
2017-06-29 17:05:08 +03:00
return nil, err
2016-09-29 15:07:04 +03:00
}
2017-04-24 12:43:15 +03:00
if err := c.resubscribe(cn); err != nil {
2017-07-09 10:07:20 +03:00
_ = c.closeConn(cn)
2017-06-29 17:05:08 +03:00
return nil, err
2017-04-24 12:43:15 +03:00
}
c.cn = cn
2017-06-29 17:05:08 +03:00
return cn, nil
}
2017-04-24 12:43:15 +03:00
func (c *PubSub) resubscribe(cn *pool.Conn) error {
var firstErr error
2018-07-23 15:55:13 +03:00
2017-04-24 12:43:15 +03:00
if len(c.channels) > 0 {
2018-07-23 15:55:13 +03:00
channels := mapKeys(c.channels)
err := c._subscribe(cn, "subscribe", channels...)
if err != nil && firstErr == nil {
firstErr = err
}
}
2018-07-23 15:55:13 +03:00
2017-04-24 12:43:15 +03:00
if len(c.patterns) > 0 {
2018-07-23 15:55:13 +03:00
patterns := mapKeys(c.patterns)
err := c._subscribe(cn, "psubscribe", patterns...)
if err != nil && firstErr == nil {
firstErr = err
}
}
2018-07-23 15:55:13 +03:00
return firstErr
}
2018-07-23 15:55:13 +03:00
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(cn *pool.Conn, redisCmd string, channels ...string) error {
args := make([]interface{}, 1+len(channels))
args[0] = redisCmd
for i, channel := range channels {
args[1+i] = channel
}
cmd := NewSliceCmd(args...)
2017-07-09 10:07:20 +03:00
cn.SetWriteTimeout(c.opt.WriteTimeout)
return writeCmd(cn, cmd)
}
2017-08-01 14:21:26 +03:00
func (c *PubSub) releaseConn(cn *pool.Conn, err error) {
2017-04-24 12:43:15 +03:00
c.mu.Lock()
2017-08-01 14:21:26 +03:00
c._releaseConn(cn, err)
2017-04-24 12:43:15 +03:00
c.mu.Unlock()
}
2017-08-01 14:21:26 +03:00
func (c *PubSub) _releaseConn(cn *pool.Conn, err error) {
2017-08-31 15:22:47 +03:00
if c.cn != cn {
return
}
if internal.IsBadConn(err, true) {
2018-07-23 15:55:13 +03:00
c._reconnect()
2017-08-01 14:21:26 +03:00
}
}
2018-07-23 15:55:13 +03:00
func (c *PubSub) _closeTheCn() error {
var err error
if c.cn != nil {
err = c.closeConn(c.cn)
c.cn = nil
}
2017-04-24 12:43:15 +03:00
return err
}
2018-07-23 15:55:13 +03:00
func (c *PubSub) reconnect() {
c.mu.Lock()
c._reconnect()
c.mu.Unlock()
}
func (c *PubSub) _reconnect() {
_ = c._closeTheCn()
_, _ = c._conn(nil)
}
2017-04-24 12:43:15 +03:00
func (c *PubSub) Close() error {
c.mu.Lock()
defer c.mu.Unlock()
if c.closed {
2017-04-24 12:43:15 +03:00
return pool.ErrClosed
}
2017-04-24 12:43:15 +03:00
c.closed = true
2018-07-23 15:55:13 +03:00
close(c.exit)
2018-07-23 15:55:13 +03:00
err := c._closeTheCn()
return err
2017-04-24 12:43:15 +03:00
}
2018-01-24 21:38:47 +03:00
// Subscribe the client to the specified channels. It returns
2017-05-11 17:02:26 +03:00
// empty subscription if there are no channels.
2015-09-06 13:50:16 +03:00
func (c *PubSub) Subscribe(channels ...string) error {
c.mu.Lock()
2018-07-23 15:55:13 +03:00
defer c.mu.Unlock()
2017-06-29 17:05:08 +03:00
err := c.subscribe("subscribe", channels...)
if c.channels == nil {
c.channels = make(map[string]struct{})
}
for _, channel := range channels {
c.channels[channel] = struct{}{}
}
2017-06-29 17:05:08 +03:00
return err
2015-09-06 13:50:16 +03:00
}
2018-01-24 21:38:47 +03:00
// PSubscribe the client to the given patterns. It returns
2017-05-11 17:02:26 +03:00
// empty subscription if there are no patterns.
2015-09-06 13:50:16 +03:00
func (c *PubSub) PSubscribe(patterns ...string) error {
c.mu.Lock()
2018-07-23 15:55:13 +03:00
defer c.mu.Unlock()
2017-06-29 17:05:08 +03:00
err := c.subscribe("psubscribe", patterns...)
if c.patterns == nil {
c.patterns = make(map[string]struct{})
}
for _, pattern := range patterns {
c.patterns[pattern] = struct{}{}
}
2017-06-29 17:05:08 +03:00
return err
2015-09-06 13:50:16 +03:00
}
2018-01-24 21:38:47 +03:00
// Unsubscribe the client from the given channels, or from all of
2015-09-06 13:50:16 +03:00
// them if none is given.
func (c *PubSub) Unsubscribe(channels ...string) error {
c.mu.Lock()
2018-07-23 15:55:13 +03:00
defer c.mu.Unlock()
2017-06-29 17:05:08 +03:00
err := c.subscribe("unsubscribe", channels...)
for _, channel := range channels {
delete(c.channels, channel)
}
2017-06-29 17:05:08 +03:00
return err
2015-09-06 13:50:16 +03:00
}
2018-01-24 21:38:47 +03:00
// PUnsubscribe the client from the given patterns, or from all of
2015-09-06 13:50:16 +03:00
// them if none is given.
func (c *PubSub) PUnsubscribe(patterns ...string) error {
c.mu.Lock()
2018-07-23 15:55:13 +03:00
defer c.mu.Unlock()
2017-06-29 17:05:08 +03:00
err := c.subscribe("punsubscribe", patterns...)
for _, pattern := range patterns {
delete(c.patterns, pattern)
}
2017-06-29 17:05:08 +03:00
return err
2015-09-06 13:50:16 +03:00
}
func (c *PubSub) subscribe(redisCmd string, channels ...string) error {
2017-07-09 10:07:20 +03:00
cn, err := c._conn(channels)
if err != nil {
return err
}
err = c._subscribe(cn, redisCmd, channels...)
2017-08-01 14:21:26 +03:00
c._releaseConn(cn, err)
return err
}
2017-02-23 16:29:38 +03:00
func (c *PubSub) Ping(payload ...string) error {
args := []interface{}{"ping"}
2017-02-23 16:29:38 +03:00
if len(payload) == 1 {
args = append(args, payload[0])
2015-07-11 13:12:47 +03:00
}
cmd := NewCmd(args...)
2017-06-29 17:05:08 +03:00
cn, err := c.conn()
if err != nil {
return err
}
2017-07-09 10:07:20 +03:00
cn.SetWriteTimeout(c.opt.WriteTimeout)
err = writeCmd(cn, cmd)
2017-08-01 14:21:26 +03:00
c.releaseConn(cn, err)
return err
2015-07-11 13:12:47 +03:00
}
2018-01-24 21:38:47 +03:00
// Subscription received after a successful subscription to channel.
2015-07-11 13:42:44 +03:00
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)
}
2015-05-23 18:17:45 +03:00
// Message received as result of a PUBLISH command issued by another client.
2012-07-25 17:00:50 +04:00
type Message struct {
2014-05-11 11:42:40 +04:00
Channel string
2015-09-06 13:50:16 +03:00
Pattern string
2014-05-11 11:42:40 +04:00
Payload string
}
2012-07-25 17:00:50 +04:00
2014-05-11 18:11:55 +04:00
func (m *Message) String() string {
return fmt.Sprintf("Message<%s: %s>", m.Channel, m.Payload)
}
2015-07-11 13:12:47 +03:00
// 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:
2015-07-11 13:12:47 +03:00
return &Pong{
Payload: reply,
2015-07-11 13:12:47 +03:00
}, nil
case []interface{}:
switch kind := reply[0].(string); kind {
case "subscribe", "unsubscribe", "psubscribe", "punsubscribe":
return &Subscription{
Kind: kind,
Channel: reply[1].(string),
Count: int(reply[2].(int64)),
}, nil
case "message":
return &Message{
Channel: reply[1].(string),
Payload: reply[2].(string),
}, nil
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)
}
2015-07-11 13:12:47 +03:00
default:
return nil, fmt.Errorf("redis: unsupported pubsub message: %#v", reply)
2015-07-11 13:12:47 +03:00
}
}
2015-07-11 13:42:44 +03:00
// ReceiveTimeout acts like Receive but returns an error if message
2015-09-06 13:50:16 +03:00
// is not received in time. This is low-level API and most clients
2018-07-23 15:55:13 +03:00
// should use ReceiveMessage instead.
2015-07-11 13:12:47 +03:00
func (c *PubSub) ReceiveTimeout(timeout time.Duration) (interface{}, error) {
if c.cmd == nil {
c.cmd = NewCmd()
}
2017-06-29 17:05:08 +03:00
cn, err := c.conn()
2015-07-11 13:12:47 +03:00
if err != nil {
return nil, err
2014-05-11 11:42:40 +04:00
}
2018-07-23 15:55:13 +03:00
cn.SetReadTimeout(timeout)
err = c.cmd.readReply(cn)
2017-08-01 14:21:26 +03:00
c.releaseConn(cn, err)
if err != nil {
2015-07-11 13:12:47 +03:00
return nil, err
}
return c.newMessage(c.cmd.Val())
2014-05-11 11:42:40 +04:00
}
2012-07-25 17:00:50 +04:00
2016-04-09 11:45:56 +03:00
// Receive returns a message as a Subscription, Message, Pong or error.
// See PubSub example for details. This is low-level API and most clients
2018-07-23 15:55:13 +03:00
// should use ReceiveMessage instead.
2015-09-06 13:50:16 +03:00
func (c *PubSub) Receive() (interface{}, error) {
return c.ReceiveTimeout(0)
}
2014-05-11 11:42:40 +04:00
// ReceiveMessage returns a Message or error ignoring Subscription or Pong
2018-07-23 15:55:13 +03:00
// messages. It periodically sends Ping messages to test connection health.
2015-09-06 13:50:16 +03:00
func (c *PubSub) ReceiveMessage() (*Message, error) {
2018-07-23 15:55:13 +03:00
c.pingOnce.Do(c.initPing)
2015-09-06 13:50:16 +03:00
for {
2018-07-23 15:55:13 +03:00
msg, err := c.Receive()
2015-09-06 13:50:16 +03:00
if err != nil {
2018-07-23 15:55:13 +03:00
return nil, err
2015-09-06 13:50:16 +03:00
}
2018-07-23 15:55:13 +03:00
// Any message is as good as a ping.
select {
case c.ping <- struct{}{}:
default:
}
2015-12-02 16:40:44 +03:00
2018-07-23 15:55:13 +03:00
switch msg := msg.(type) {
2015-09-06 13:50:16 +03:00
case *Subscription:
// Ignore.
case *Pong:
// Ignore.
case *Message:
return msg, nil
default:
2018-07-23 15:55:13 +03:00
err := fmt.Errorf("redis: unknown message: %T", msg)
return nil, err
2015-09-06 13:50:16 +03:00
}
}
}
2017-10-30 13:09:57 +03:00
// Channel returns a Go channel for concurrently receiving messages.
2018-07-23 15:55:13 +03:00
// The channel is closed with PubSub. Receive* APIs can not be used
// after channel is created.
2017-04-11 16:18:35 +03:00
func (c *PubSub) Channel() <-chan *Message {
2018-07-23 15:55:13 +03:00
c.chOnce.Do(c.initChannel)
return c.ch
}
func (c *PubSub) initChannel() {
c.ch = make(chan *Message, 100)
go func() {
var errCount int
for {
msg, err := c.ReceiveMessage()
if err != nil {
if err == pool.ErrClosed {
close(c.ch)
return
}
if errCount > 0 {
time.Sleep(c.retryBackoff(errCount))
2017-04-11 16:18:35 +03:00
}
2018-07-23 15:55:13 +03:00
errCount++
continue
2017-04-11 16:18:35 +03:00
}
2018-07-23 15:55:13 +03:00
errCount = 0
c.ch <- msg
}
}()
}
func (c *PubSub) initPing() {
const timeout = 5 * time.Second
c.ping = make(chan struct{}, 10)
go func() {
timer := time.NewTimer(timeout)
timer.Stop()
var hasPing bool
for {
timer.Reset(timeout)
select {
case <-c.ping:
hasPing = true
if !timer.Stop() {
<-timer.C
}
case <-timer.C:
if hasPing {
hasPing = false
_ = c.Ping()
} else {
c.reconnect()
}
case <-c.exit:
return
}
}
}()
}
func (c *PubSub) retryBackoff(attempt int) time.Duration {
return internal.RetryBackoff(attempt, c.opt.MinRetryBackoff, c.opt.MaxRetryBackoff)
2017-04-11 16:18:35 +03:00
}