2019-01-23 01:39:42 +03:00
|
|
|
// Package stan provides a NATS Streaming broker
|
|
|
|
package stan
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"errors"
|
2019-02-10 13:16:41 +03:00
|
|
|
"fmt"
|
2019-01-23 01:39:42 +03:00
|
|
|
"strings"
|
|
|
|
"sync"
|
2019-02-10 13:16:41 +03:00
|
|
|
"time"
|
2019-01-23 01:39:42 +03:00
|
|
|
|
|
|
|
"github.com/google/uuid"
|
2020-01-31 01:26:39 +03:00
|
|
|
"github.com/micro/go-micro/v2/broker"
|
|
|
|
"github.com/micro/go-micro/v2/codec/json"
|
2020-07-14 23:27:09 +03:00
|
|
|
"github.com/micro/go-micro/v2/cmd"
|
2020-02-25 17:26:54 +03:00
|
|
|
log "github.com/micro/go-micro/v2/logger"
|
2019-05-30 06:45:20 +03:00
|
|
|
stan "github.com/nats-io/stan.go"
|
2019-01-23 01:39:42 +03:00
|
|
|
)
|
|
|
|
|
|
|
|
type stanBroker struct {
|
|
|
|
sync.RWMutex
|
2019-02-12 17:27:14 +03:00
|
|
|
addrs []string
|
|
|
|
conn stan.Conn
|
|
|
|
opts broker.Options
|
|
|
|
sopts stan.Options
|
|
|
|
nopts []stan.Option
|
|
|
|
clusterID string
|
2019-04-26 13:19:42 +03:00
|
|
|
clientID string
|
2019-02-12 17:27:14 +03:00
|
|
|
connectTimeout time.Duration
|
|
|
|
connectRetry bool
|
|
|
|
done chan struct{}
|
|
|
|
ctx context.Context
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
type subscriber struct {
|
|
|
|
t string
|
|
|
|
s stan.Subscription
|
|
|
|
dq bool
|
|
|
|
opts broker.SubscribeOptions
|
|
|
|
}
|
|
|
|
|
|
|
|
type publication struct {
|
|
|
|
t string
|
|
|
|
msg *stan.Msg
|
|
|
|
m *broker.Message
|
2020-03-07 13:32:35 +03:00
|
|
|
err error
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
func init() {
|
|
|
|
cmd.DefaultBrokers["stan"] = NewBroker
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *publication) Topic() string {
|
|
|
|
return n.t
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *publication) Message() *broker.Message {
|
|
|
|
return n.m
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *publication) Ack() error {
|
|
|
|
return n.msg.Ack()
|
|
|
|
}
|
|
|
|
|
2020-03-07 13:32:35 +03:00
|
|
|
func (n *publication) Error() error {
|
|
|
|
return n.err
|
|
|
|
}
|
|
|
|
|
2019-01-23 01:39:42 +03:00
|
|
|
func (n *subscriber) Options() broker.SubscribeOptions {
|
|
|
|
return n.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *subscriber) Topic() string {
|
|
|
|
return n.t
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *subscriber) Unsubscribe() error {
|
|
|
|
if n.s == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
// go-micro server Unsubscribe can't handle durable queues, so close as stan suggested
|
|
|
|
// from nats streaming readme:
|
|
|
|
// When a client disconnects, the streaming server is not notified, hence the importance of calling Close()
|
|
|
|
if !n.dq {
|
|
|
|
err := n.s.Unsubscribe()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return n.Close()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *subscriber) Close() error {
|
|
|
|
if n.s != nil {
|
|
|
|
return n.s.Close()
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Address() string {
|
|
|
|
// stan does not support connected server info
|
|
|
|
if len(n.addrs) > 0 {
|
|
|
|
return n.addrs[0]
|
|
|
|
}
|
|
|
|
|
|
|
|
return ""
|
|
|
|
}
|
|
|
|
|
|
|
|
func setAddrs(addrs []string) []string {
|
2019-12-04 13:36:30 +03:00
|
|
|
cAddrs := make([]string, 0, len(addrs))
|
2019-01-23 01:39:42 +03:00
|
|
|
for _, addr := range addrs {
|
|
|
|
if len(addr) == 0 {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
if !strings.HasPrefix(addr, "nats://") {
|
|
|
|
addr = "nats://" + addr
|
|
|
|
}
|
|
|
|
cAddrs = append(cAddrs, addr)
|
|
|
|
}
|
|
|
|
if len(cAddrs) == 0 {
|
|
|
|
cAddrs = []string{stan.DefaultNatsURL}
|
|
|
|
}
|
|
|
|
return cAddrs
|
|
|
|
}
|
|
|
|
|
2019-02-10 13:16:41 +03:00
|
|
|
func (n *stanBroker) reconnectCB(c stan.Conn, err error) {
|
2019-02-12 17:27:14 +03:00
|
|
|
if n.connectRetry {
|
2019-02-10 13:16:41 +03:00
|
|
|
if err := n.connect(); err != nil {
|
2020-02-25 17:26:54 +03:00
|
|
|
log.Error(err)
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) connect() error {
|
|
|
|
timeout := make(<-chan time.Time)
|
|
|
|
|
2019-06-19 00:59:44 +03:00
|
|
|
n.RLock()
|
2019-02-12 17:27:14 +03:00
|
|
|
if n.connectTimeout > 0 {
|
|
|
|
timeout = time.After(n.connectTimeout)
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
2019-06-19 00:59:44 +03:00
|
|
|
clusterID := n.clusterID
|
|
|
|
clientID := n.clientID
|
|
|
|
nopts := n.nopts
|
|
|
|
n.RUnlock()
|
2019-02-10 13:16:41 +03:00
|
|
|
|
|
|
|
ticker := time.NewTicker(1 * time.Second)
|
|
|
|
defer ticker.Stop()
|
|
|
|
|
|
|
|
fn := func() error {
|
2019-06-19 00:59:44 +03:00
|
|
|
c, err := stan.Connect(clusterID, clientID, nopts...)
|
2019-02-10 13:16:41 +03:00
|
|
|
if err == nil {
|
|
|
|
n.Lock()
|
|
|
|
n.conn = c
|
|
|
|
n.Unlock()
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// don't wait for first try
|
|
|
|
if err := fn(); err == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-05-09 23:48:37 +03:00
|
|
|
n.RLock()
|
|
|
|
done := n.done
|
|
|
|
n.RUnlock()
|
|
|
|
|
2019-02-10 13:16:41 +03:00
|
|
|
// wait loop
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
// context closed
|
|
|
|
case <-n.opts.Context.Done():
|
|
|
|
return nil
|
|
|
|
// call close, don't wait anymore
|
2019-05-09 23:48:37 +03:00
|
|
|
case <-done:
|
2019-02-10 13:16:41 +03:00
|
|
|
return nil
|
|
|
|
// in case of timeout fail with a timeout error
|
|
|
|
case <-timeout:
|
2019-02-12 17:27:14 +03:00
|
|
|
return fmt.Errorf("[stan]: timeout connect to %v", n.addrs)
|
2019-02-10 13:16:41 +03:00
|
|
|
// got a tick, try to connect
|
|
|
|
case <-ticker.C:
|
|
|
|
err := fn()
|
|
|
|
if err == nil {
|
2020-02-25 17:26:54 +03:00
|
|
|
log.Infof("[stan]: successeful connected to %v", n.addrs)
|
2019-02-10 13:16:41 +03:00
|
|
|
return nil
|
|
|
|
}
|
2020-02-25 17:26:54 +03:00
|
|
|
log.Errorf("[stan]: failed to connect %v: %v\n", n.addrs, err)
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-01-23 01:39:42 +03:00
|
|
|
func (n *stanBroker) Connect() error {
|
|
|
|
n.RLock()
|
|
|
|
if n.conn != nil {
|
|
|
|
n.RUnlock()
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
n.RUnlock()
|
|
|
|
|
|
|
|
clusterID, ok := n.opts.Context.Value(clusterIDKey{}).(string)
|
|
|
|
if !ok || len(clusterID) == 0 {
|
|
|
|
return errors.New("must specify ClusterID Option")
|
|
|
|
}
|
|
|
|
|
2019-04-26 13:19:42 +03:00
|
|
|
clientID, ok := n.opts.Context.Value(clientIDKey{}).(string)
|
|
|
|
if !ok || len(clientID) == 0 {
|
|
|
|
clientID = uuid.New().String()
|
|
|
|
}
|
|
|
|
|
2019-06-19 00:59:44 +03:00
|
|
|
n.Lock()
|
2019-02-12 17:27:14 +03:00
|
|
|
if v, ok := n.opts.Context.Value(connectRetryKey{}).(bool); ok && v {
|
|
|
|
n.connectRetry = true
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
2019-01-23 01:39:42 +03:00
|
|
|
|
2019-02-12 17:27:14 +03:00
|
|
|
if td, ok := n.opts.Context.Value(connectTimeoutKey{}).(time.Duration); ok {
|
|
|
|
n.connectTimeout = td
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
2019-02-12 17:27:14 +03:00
|
|
|
if n.sopts.ConnectionLostCB != nil && n.connectRetry {
|
2019-06-19 00:59:44 +03:00
|
|
|
n.Unlock()
|
2019-02-12 17:27:14 +03:00
|
|
|
return errors.New("impossible to use custom ConnectionLostCB and ConnectRetry(true)")
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
nopts := []stan.Option{
|
|
|
|
stan.NatsURL(n.sopts.NatsURL),
|
|
|
|
stan.NatsConn(n.sopts.NatsConn),
|
|
|
|
stan.ConnectWait(n.sopts.ConnectTimeout),
|
|
|
|
stan.PubAckWait(n.sopts.AckTimeout),
|
|
|
|
stan.MaxPubAcksInflight(n.sopts.MaxPubAcksInflight),
|
2019-05-30 06:45:20 +03:00
|
|
|
stan.Pings(n.sopts.PingInterval, n.sopts.PingMaxOut),
|
2019-02-10 13:16:41 +03:00
|
|
|
}
|
2019-06-19 03:09:12 +03:00
|
|
|
|
|
|
|
if n.connectRetry {
|
|
|
|
nopts = append(nopts, stan.SetConnectionLostHandler(n.reconnectCB))
|
|
|
|
}
|
|
|
|
|
2019-02-10 13:16:41 +03:00
|
|
|
nopts = append(nopts, stan.NatsURL(strings.Join(n.addrs, ",")))
|
|
|
|
|
|
|
|
n.nopts = nopts
|
|
|
|
n.clusterID = clusterID
|
2019-04-26 13:19:42 +03:00
|
|
|
n.clientID = clientID
|
2019-01-23 01:39:42 +03:00
|
|
|
n.Unlock()
|
2019-02-10 13:16:41 +03:00
|
|
|
|
|
|
|
return n.connect()
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Disconnect() error {
|
2019-02-10 13:16:41 +03:00
|
|
|
var err error
|
|
|
|
|
|
|
|
n.Lock()
|
|
|
|
defer n.Unlock()
|
|
|
|
|
|
|
|
if n.done != nil {
|
|
|
|
close(n.done)
|
|
|
|
n.done = nil
|
|
|
|
}
|
|
|
|
if n.conn != nil {
|
|
|
|
err = n.conn.Close()
|
|
|
|
}
|
|
|
|
return err
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Init(opts ...broker.Option) error {
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&n.opts)
|
|
|
|
}
|
|
|
|
n.addrs = setAddrs(n.opts.Addrs)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Options() broker.Options {
|
|
|
|
return n.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Publish(topic string, msg *broker.Message, opts ...broker.PublishOption) error {
|
|
|
|
b, err := n.opts.Codec.Marshal(msg)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
n.RLock()
|
|
|
|
defer n.RUnlock()
|
|
|
|
return n.conn.Publish(topic, b)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) Subscribe(topic string, handler broker.Handler, opts ...broker.SubscribeOption) (broker.Subscriber, error) {
|
2019-06-22 00:25:50 +03:00
|
|
|
n.RLock()
|
2019-01-26 13:37:58 +03:00
|
|
|
if n.conn == nil {
|
2019-06-22 00:25:50 +03:00
|
|
|
n.RUnlock()
|
2019-01-26 13:37:58 +03:00
|
|
|
return nil, errors.New("not connected")
|
|
|
|
}
|
2019-06-22 00:25:50 +03:00
|
|
|
n.RUnlock()
|
|
|
|
|
2019-01-28 11:18:02 +03:00
|
|
|
var ackSuccess bool
|
2019-01-23 01:39:42 +03:00
|
|
|
|
|
|
|
opt := broker.SubscribeOptions{
|
|
|
|
AutoAck: true,
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&opt)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Make sure context is setup
|
|
|
|
if opt.Context == nil {
|
|
|
|
opt.Context = context.Background()
|
|
|
|
}
|
|
|
|
|
|
|
|
ctx := opt.Context
|
|
|
|
if subscribeContext, ok := ctx.Value(subscribeContextKey{}).(context.Context); ok && subscribeContext != nil {
|
|
|
|
ctx = subscribeContext
|
|
|
|
}
|
|
|
|
|
|
|
|
var stanOpts []stan.SubscriptionOption
|
2019-01-26 13:37:58 +03:00
|
|
|
if !opt.AutoAck {
|
2019-01-23 01:39:42 +03:00
|
|
|
stanOpts = append(stanOpts, stan.SetManualAckMode())
|
|
|
|
}
|
|
|
|
|
|
|
|
if subOpts, ok := ctx.Value(subscribeOptionKey{}).([]stan.SubscriptionOption); ok && len(subOpts) > 0 {
|
|
|
|
stanOpts = append(stanOpts, subOpts...)
|
|
|
|
}
|
|
|
|
|
2019-01-28 11:18:02 +03:00
|
|
|
if bval, ok := ctx.Value(ackSuccessKey{}).(bool); ok && bval {
|
2019-01-23 01:39:42 +03:00
|
|
|
stanOpts = append(stanOpts, stan.SetManualAckMode())
|
2019-01-28 11:18:02 +03:00
|
|
|
ackSuccess = true
|
2019-01-23 01:39:42 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
bopts := stan.DefaultSubscriptionOptions
|
|
|
|
for _, bopt := range stanOpts {
|
|
|
|
if err := bopt(&bopts); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2019-01-26 13:37:58 +03:00
|
|
|
opt.AutoAck = !bopts.ManualAcks
|
|
|
|
|
2019-05-29 16:57:48 +03:00
|
|
|
if dn, ok := n.opts.Context.Value(durableKey{}).(string); ok && len(dn) > 0 {
|
|
|
|
stanOpts = append(stanOpts, stan.DurableName(dn))
|
|
|
|
bopts.DurableName = dn
|
|
|
|
}
|
|
|
|
|
2019-01-23 01:39:42 +03:00
|
|
|
fn := func(msg *stan.Msg) {
|
|
|
|
var m broker.Message
|
2020-03-07 13:32:35 +03:00
|
|
|
p := &publication{m: &m, msg: msg, t: msg.Subject}
|
2019-01-28 11:02:42 +03:00
|
|
|
|
|
|
|
// unmarshal message
|
|
|
|
if err := n.opts.Codec.Unmarshal(msg.Data, &m); err != nil {
|
2020-03-07 13:32:35 +03:00
|
|
|
p.err = err
|
|
|
|
p.m.Body = msg.Data
|
2019-01-23 01:39:42 +03:00
|
|
|
return
|
|
|
|
}
|
2019-01-28 11:02:42 +03:00
|
|
|
// execute the handler
|
2020-03-07 13:32:35 +03:00
|
|
|
p.err = handler(p)
|
2019-01-28 11:02:42 +03:00
|
|
|
// if there's no error and success auto ack is enabled ack it
|
2020-03-07 13:32:35 +03:00
|
|
|
if p.err == nil && ackSuccess {
|
2019-01-23 01:39:42 +03:00
|
|
|
msg.Ack()
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
var sub stan.Subscription
|
|
|
|
var err error
|
|
|
|
|
|
|
|
n.RLock()
|
|
|
|
if len(opt.Queue) > 0 {
|
|
|
|
sub, err = n.conn.QueueSubscribe(topic, opt.Queue, fn, stanOpts...)
|
|
|
|
} else {
|
|
|
|
sub, err = n.conn.Subscribe(topic, fn, stanOpts...)
|
|
|
|
}
|
|
|
|
n.RUnlock()
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return &subscriber{dq: len(bopts.DurableName) > 0, s: sub, opts: opt, t: topic}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *stanBroker) String() string {
|
|
|
|
return "stan"
|
|
|
|
}
|
|
|
|
|
|
|
|
func NewBroker(opts ...broker.Option) broker.Broker {
|
|
|
|
options := broker.Options{
|
|
|
|
// Default codec
|
|
|
|
Codec: json.Marshaler{},
|
|
|
|
Context: context.Background(),
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&options)
|
|
|
|
}
|
|
|
|
|
2019-05-29 16:57:48 +03:00
|
|
|
stanOpts := stan.GetDefaultOptions()
|
2019-01-23 01:39:42 +03:00
|
|
|
if n, ok := options.Context.Value(optionsKey{}).(stan.Options); ok {
|
|
|
|
stanOpts = n
|
|
|
|
}
|
|
|
|
|
|
|
|
if len(options.Addrs) == 0 {
|
|
|
|
options.Addrs = strings.Split(stanOpts.NatsURL, ",")
|
|
|
|
}
|
|
|
|
|
|
|
|
nb := &stanBroker{
|
2019-02-10 13:16:41 +03:00
|
|
|
done: make(chan struct{}),
|
2019-01-23 01:39:42 +03:00
|
|
|
opts: options,
|
2019-02-10 13:16:41 +03:00
|
|
|
sopts: stanOpts,
|
2019-01-23 01:39:42 +03:00
|
|
|
addrs: setAddrs(options.Addrs),
|
|
|
|
}
|
|
|
|
|
|
|
|
return nb
|
|
|
|
}
|