redis/pubsub.go

303 lines
6.8 KiB
Go
Raw Normal View History

2012-07-25 17:00:50 +04:00
package redis
import (
"fmt"
2015-09-06 13:50:16 +03:00
"net"
2014-05-11 11:42:40 +04:00
"time"
2012-07-25 17:00:50 +04:00
)
2015-07-11 13:42:44 +03:00
// Posts a message to the given channel.
func (c *Client) Publish(channel, message string) *IntCmd {
req := NewIntCmd("PUBLISH", channel, message)
c.Process(req)
return req
}
2015-05-23 14:15:05 +03:00
// PubSub implements Pub/Sub commands as described in
2015-09-12 09:36:03 +03:00
// http://redis.io/topics/pubsub. It's NOT safe for concurrent use by
// multiple goroutines.
2014-05-11 11:42:40 +04:00
type PubSub struct {
*baseClient
2015-09-06 13:50:16 +03:00
channels []string
patterns []string
2012-07-25 17:00:50 +04:00
}
2015-07-11 13:42:44 +03:00
// Deprecated. Use Subscribe/PSubscribe instead.
2014-05-11 11:42:40 +04:00
func (c *Client) PubSub() *PubSub {
return &PubSub{
baseClient: &baseClient{
opt: c.opt,
connPool: newStickyConnPool(c.connPool, false),
},
2014-05-11 11:42:40 +04:00
}
}
2015-07-11 13:42:44 +03:00
// Subscribes the client to the specified channels.
func (c *Client) Subscribe(channels ...string) (*PubSub, error) {
pubsub := c.PubSub()
return pubsub, pubsub.Subscribe(channels...)
}
// Subscribes the client to the given patterns.
func (c *Client) PSubscribe(channels ...string) (*PubSub, error) {
pubsub := c.PubSub()
return pubsub, pubsub.PSubscribe(channels...)
2012-07-25 17:00:50 +04:00
}
2015-09-06 13:50:16 +03:00
func (c *PubSub) subscribe(cmd string, channels ...string) error {
cn, _, err := c.conn()
2015-09-06 13:50:16 +03:00
if err != nil {
return err
}
args := make([]interface{}, 1+len(channels))
args[0] = cmd
for i, channel := range channels {
args[1+i] = channel
}
req := NewSliceCmd(args...)
return cn.writeCmds(req)
}
// Subscribes the client to the specified channels.
func (c *PubSub) Subscribe(channels ...string) error {
err := c.subscribe("SUBSCRIBE", channels...)
if err == nil {
c.channels = append(c.channels, channels...)
}
return err
}
// Subscribes the client to the given patterns.
func (c *PubSub) PSubscribe(patterns ...string) error {
err := c.subscribe("PSUBSCRIBE", patterns...)
if err == nil {
c.patterns = append(c.patterns, patterns...)
2015-09-06 13:50:16 +03:00
}
return err
}
func remove(ss []string, es ...string) []string {
2015-11-22 15:44:38 +03:00
if len(es) == 0 {
return ss[:0]
}
2015-09-06 13:50:16 +03:00
for _, e := range es {
for i, s := range ss {
if s == e {
ss = append(ss[:i], ss[i+1:]...)
break
}
}
}
return ss
}
// Unsubscribes the client from the given channels, or from all of
// them if none is given.
func (c *PubSub) Unsubscribe(channels ...string) error {
err := c.subscribe("UNSUBSCRIBE", channels...)
if err == nil {
c.channels = remove(c.channels, channels...)
}
return err
}
// Unsubscribes the client from the given patterns, or from all of
// them if none is given.
func (c *PubSub) PUnsubscribe(patterns ...string) error {
err := c.subscribe("PUNSUBSCRIBE", patterns...)
if err == nil {
c.patterns = remove(c.patterns, patterns...)
}
return err
}
2015-07-11 13:12:47 +03:00
func (c *PubSub) Ping(payload string) error {
cn, _, err := c.conn()
2015-07-11 13:12:47 +03:00
if err != nil {
return err
}
args := []interface{}{"PING"}
if payload != "" {
args = append(args, payload)
}
cmd := NewCmd(args...)
return cn.writeCmds(cmd)
}
2015-07-11 13:42:44 +03:00
// Message 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)
}
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-09-06 13:50:16 +03:00
// TODO: remove PMessage if favor of Message
2015-05-23 18:17:45 +03:00
// Message matching a pattern-matching subscription received as result
// of a PUBLISH command issued by another client.
2014-05-11 11:42:40 +04:00
type PMessage struct {
Channel string
Pattern string
Payload string
2012-07-25 17:00:50 +04:00
}
2014-05-11 18:11:55 +04:00
func (m *PMessage) String() string {
return fmt.Sprintf("PMessage<%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 newMessage(reply []interface{}) (interface{}, error) {
switch kind := reply[0].(string); kind {
2014-05-11 11:42:40 +04:00
case "subscribe", "unsubscribe", "psubscribe", "punsubscribe":
return &Subscription{
Kind: kind,
2014-05-11 11:42:40 +04:00
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 &PMessage{
Pattern: reply[1].(string),
Channel: reply[2].(string),
Payload: reply[3].(string),
}, nil
2015-07-11 13:12:47 +03:00
case "pong":
return &Pong{
Payload: reply[1].(string),
}, nil
default:
return nil, fmt.Errorf("redis: unsupported pubsub notification: %q", kind)
}
}
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
// should use ReceiveMessage.
2015-07-11 13:12:47 +03:00
func (c *PubSub) ReceiveTimeout(timeout time.Duration) (interface{}, error) {
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
}
2015-07-11 13:12:47 +03:00
cn.ReadTimeout = timeout
2015-07-11 13:12:47 +03:00
cmd := NewSliceCmd()
err = cmd.readReply(cn)
c.putConn(cn, err)
if err != nil {
2015-07-11 13:12:47 +03:00
return nil, err
}
return newMessage(cmd.Val())
2014-05-11 11:42:40 +04:00
}
2012-07-25 17:00:50 +04:00
2015-09-06 13:50:16 +03:00
// Receive returns a message as a Subscription, Message, PMessage,
// Pong or error. See PubSub example for details. This is low-level
// API and most clients should use ReceiveMessage.
func (c *PubSub) Receive() (interface{}, error) {
return c.ReceiveTimeout(0)
}
2014-05-11 11:42:40 +04:00
2015-12-22 16:45:03 +03:00
func (c *PubSub) reconnect(reason error) {
2015-11-22 15:44:38 +03:00
// Close current connection.
2015-12-22 16:45:03 +03:00
c.connPool.(*stickyConnPool).Reset(reason)
2015-11-22 15:44:38 +03:00
2015-09-06 13:50:16 +03:00
if len(c.channels) > 0 {
if err := c.Subscribe(c.channels...); err != nil {
Logger.Printf("redis: Subscribe failed: %s", err)
2015-09-06 13:50:16 +03:00
}
}
if len(c.patterns) > 0 {
if err := c.PSubscribe(c.patterns...); err != nil {
Logger.Printf("redis: PSubscribe failed: %s", err)
2015-09-06 13:50:16 +03:00
}
}
2012-07-25 17:00:50 +04:00
}
2015-09-06 13:50:16 +03:00
// ReceiveMessage returns a message or error. It automatically
// reconnects to Redis in case of network errors.
func (c *PubSub) ReceiveMessage() (*Message, error) {
2015-12-02 16:40:44 +03:00
var errNum int
2015-09-06 13:50:16 +03:00
for {
msgi, err := c.ReceiveTimeout(5 * time.Second)
if err != nil {
2015-12-02 16:40:44 +03:00
if !isNetworkError(err) {
return nil, err
}
goodConn := errNum == 0
errNum++
2015-12-02 16:40:44 +03:00
if goodConn {
if netErr, ok := err.(net.Error); ok && netErr.Timeout() {
err := c.Ping("")
if err == nil {
continue
}
Logger.Printf("redis: PubSub.Ping failed: %s", err)
2015-09-06 13:50:16 +03:00
}
}
2015-12-02 16:40:44 +03:00
if errNum > 2 {
time.Sleep(time.Second)
2015-09-06 13:50:16 +03:00
}
2015-12-22 16:45:03 +03:00
c.reconnect(err)
2015-12-02 16:40:44 +03:00
continue
2015-09-06 13:50:16 +03:00
}
2015-12-02 16:40:44 +03:00
// Reset error number.
errNum = 0
2015-09-06 13:50:16 +03:00
switch msg := msgi.(type) {
case *Subscription:
// Ignore.
case *Pong:
// Ignore.
case *Message:
return msg, nil
case *PMessage:
return &Message{
Channel: msg.Channel,
Pattern: msg.Pattern,
Payload: msg.Payload,
}, nil
default:
return nil, fmt.Errorf("redis: unknown message: %T", msgi)
}
}
}