2019-05-29 18:46:57 +03:00
|
|
|
// Package nats provides a NATS broker
|
|
|
|
package nats
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"errors"
|
2020-01-14 16:23:16 +03:00
|
|
|
"net"
|
|
|
|
"net/url"
|
|
|
|
"strconv"
|
2019-05-29 18:46:57 +03:00
|
|
|
"strings"
|
|
|
|
"sync"
|
2020-01-14 16:23:16 +03:00
|
|
|
"time"
|
2019-05-29 18:46:57 +03:00
|
|
|
|
2020-01-30 14:39:00 +03:00
|
|
|
"github.com/micro/go-micro/v2/broker"
|
|
|
|
"github.com/micro/go-micro/v2/codec/json"
|
2020-02-23 16:45:20 +03:00
|
|
|
log "github.com/micro/go-micro/v2/logger"
|
2020-01-30 14:39:00 +03:00
|
|
|
"github.com/micro/go-micro/v2/registry"
|
|
|
|
"github.com/micro/go-micro/v2/util/addr"
|
2020-01-14 16:23:16 +03:00
|
|
|
"github.com/nats-io/nats-server/v2/server"
|
2019-05-29 18:46:57 +03:00
|
|
|
nats "github.com/nats-io/nats.go"
|
|
|
|
)
|
|
|
|
|
|
|
|
type natsBroker struct {
|
2019-08-07 12:58:45 +03:00
|
|
|
sync.Once
|
2019-05-29 18:46:57 +03:00
|
|
|
sync.RWMutex
|
2020-01-14 16:23:16 +03:00
|
|
|
|
|
|
|
// indicate if we're connected
|
|
|
|
connected bool
|
|
|
|
|
|
|
|
addrs []string
|
|
|
|
conn *nats.Conn
|
|
|
|
opts broker.Options
|
|
|
|
nopts nats.Options
|
|
|
|
|
|
|
|
// should we drain the connection
|
2019-08-07 12:58:45 +03:00
|
|
|
drain bool
|
|
|
|
closeCh chan (error)
|
2020-01-14 16:23:16 +03:00
|
|
|
|
|
|
|
// embedded server
|
|
|
|
server *server.Server
|
|
|
|
// configure to use local server
|
|
|
|
local bool
|
|
|
|
// server exit channel
|
|
|
|
exit chan bool
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
type subscriber struct {
|
2019-08-07 12:58:45 +03:00
|
|
|
s *nats.Subscription
|
|
|
|
opts broker.SubscribeOptions
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
type publication struct {
|
|
|
|
t string
|
|
|
|
m *broker.Message
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *publication) Topic() string {
|
|
|
|
return p.t
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *publication) Message() *broker.Message {
|
|
|
|
return p.m
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *publication) Ack() error {
|
|
|
|
// nats does not support acking
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (s *subscriber) Options() broker.SubscribeOptions {
|
|
|
|
return s.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (s *subscriber) Topic() string {
|
|
|
|
return s.s.Subject
|
|
|
|
}
|
|
|
|
|
|
|
|
func (s *subscriber) Unsubscribe() error {
|
|
|
|
return s.s.Unsubscribe()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) Address() string {
|
|
|
|
if n.conn != nil && n.conn.IsConnected() {
|
|
|
|
return n.conn.ConnectedUrl()
|
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
|
2019-05-29 18:46:57 +03:00
|
|
|
if len(n.addrs) > 0 {
|
|
|
|
return n.addrs[0]
|
|
|
|
}
|
|
|
|
|
|
|
|
return ""
|
|
|
|
}
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
func (n *natsBroker) setAddrs(addrs []string) []string {
|
2019-12-03 22:59:44 +03:00
|
|
|
//nolint:prealloc
|
2019-05-29 18:46:57 +03:00
|
|
|
var cAddrs []string
|
|
|
|
for _, addr := range addrs {
|
|
|
|
if len(addr) == 0 {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
if !strings.HasPrefix(addr, "nats://") {
|
|
|
|
addr = "nats://" + addr
|
|
|
|
}
|
|
|
|
cAddrs = append(cAddrs, addr)
|
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
// if there's no address and we weren't told to
|
|
|
|
// embed a local server then use the default url
|
|
|
|
if len(cAddrs) == 0 && !n.local {
|
2019-05-29 18:46:57 +03:00
|
|
|
cAddrs = []string{nats.DefaultURL}
|
|
|
|
}
|
|
|
|
return cAddrs
|
|
|
|
}
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
// serve stats a local nats server if needed
|
|
|
|
func (n *natsBroker) serve(exit chan bool) error {
|
|
|
|
var host string
|
|
|
|
var port int
|
|
|
|
var local bool
|
|
|
|
|
|
|
|
// with no address we just default it
|
|
|
|
// this is a local client address
|
2020-01-18 04:29:53 +03:00
|
|
|
if len(n.addrs) == 0 {
|
2020-01-18 18:39:26 +03:00
|
|
|
// find an advertiseable ip
|
|
|
|
if h, err := addr.Extract(""); err != nil {
|
|
|
|
host = "127.0.0.1"
|
|
|
|
} else {
|
|
|
|
host = h
|
|
|
|
}
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
port = -1
|
|
|
|
local = true
|
|
|
|
} else {
|
|
|
|
address := n.addrs[0]
|
|
|
|
if strings.HasPrefix(address, "nats://") {
|
|
|
|
address = strings.TrimPrefix(address, "nats://")
|
|
|
|
}
|
|
|
|
|
2020-01-18 04:29:53 +03:00
|
|
|
// check if its a local address and only then embed
|
2020-01-14 16:23:16 +03:00
|
|
|
if addr.IsLocal(address) {
|
|
|
|
h, p, err := net.SplitHostPort(address)
|
|
|
|
if err == nil {
|
|
|
|
host = h
|
|
|
|
port, _ = strconv.Atoi(p)
|
|
|
|
local = true
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// we only setup a server for local things
|
|
|
|
if !local {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// 1. create new server
|
|
|
|
// 2. register the server
|
|
|
|
// 3. connect to other servers
|
|
|
|
var cOpts server.ClusterOpts
|
|
|
|
var routes []*url.URL
|
|
|
|
|
|
|
|
// get existing nats servers to connect to
|
|
|
|
services, err := n.opts.Registry.GetService("go.micro.nats.broker")
|
|
|
|
if err == nil {
|
|
|
|
for _, service := range services {
|
|
|
|
for _, node := range service.Nodes {
|
|
|
|
u, err := url.Parse("nats://" + node.Address)
|
|
|
|
if err != nil {
|
2020-02-23 16:45:20 +03:00
|
|
|
log.Error(err)
|
2020-01-14 16:23:16 +03:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
// append to the cluster routes
|
|
|
|
routes = append(routes, u)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// try get existing server
|
|
|
|
s := n.server
|
|
|
|
|
|
|
|
// get a host address
|
|
|
|
caddr, err := addr.Extract("")
|
|
|
|
if err != nil {
|
|
|
|
caddr = "0.0.0.0"
|
|
|
|
}
|
|
|
|
|
|
|
|
// set cluster opts
|
|
|
|
cOpts = server.ClusterOpts{
|
|
|
|
Host: caddr,
|
|
|
|
Port: -1,
|
|
|
|
}
|
|
|
|
|
|
|
|
if s == nil {
|
|
|
|
var err error
|
|
|
|
s, err = server.NewServer(&server.Options{
|
|
|
|
// Specify the host
|
|
|
|
Host: host,
|
|
|
|
// Use a random port
|
|
|
|
Port: port,
|
|
|
|
// Set the cluster ops
|
|
|
|
Cluster: cOpts,
|
|
|
|
// Set the routes
|
|
|
|
Routes: routes,
|
|
|
|
NoLog: true,
|
|
|
|
NoSigs: true,
|
|
|
|
MaxControlLine: 2048,
|
|
|
|
TLSConfig: n.opts.TLSConfig,
|
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// save the server
|
|
|
|
n.server = s
|
|
|
|
}
|
|
|
|
|
|
|
|
// start the server
|
|
|
|
go s.Start()
|
|
|
|
|
|
|
|
var ready bool
|
|
|
|
|
|
|
|
// wait till its ready for connections
|
|
|
|
for i := 0; i < 3; i++ {
|
|
|
|
if s.ReadyForConnections(time.Second) {
|
|
|
|
ready = true
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if !ready {
|
|
|
|
return errors.New("server not ready")
|
|
|
|
}
|
|
|
|
|
|
|
|
// set the client address
|
|
|
|
n.addrs = []string{s.ClientURL()}
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
// register the cluster address
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-exit:
|
|
|
|
// deregister on exit
|
|
|
|
n.opts.Registry.Deregister(®istry.Service{
|
|
|
|
Name: "go.micro.nats.broker",
|
|
|
|
Version: "v2",
|
|
|
|
Nodes: []*registry.Node{
|
|
|
|
{Id: s.ID(), Address: s.ClusterAddr().String()},
|
|
|
|
},
|
|
|
|
})
|
|
|
|
s.Shutdown()
|
|
|
|
return
|
|
|
|
default:
|
|
|
|
// register the broker
|
|
|
|
n.opts.Registry.Register(®istry.Service{
|
|
|
|
Name: "go.micro.nats.broker",
|
|
|
|
Version: "v2",
|
|
|
|
Nodes: []*registry.Node{
|
|
|
|
{Id: s.ID(), Address: s.ClusterAddr().String()},
|
|
|
|
},
|
|
|
|
}, registry.RegisterTTL(time.Minute))
|
|
|
|
time.Sleep(time.Minute)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-05-29 18:46:57 +03:00
|
|
|
func (n *natsBroker) Connect() error {
|
|
|
|
n.Lock()
|
|
|
|
defer n.Unlock()
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
if !n.connected {
|
|
|
|
// create exit chan
|
|
|
|
n.exit = make(chan bool)
|
|
|
|
|
2020-01-18 04:29:53 +03:00
|
|
|
// start embedded server if asked to
|
|
|
|
if n.local {
|
|
|
|
if err := n.serve(n.exit); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
// set to connected
|
|
|
|
n.connected = true
|
|
|
|
}
|
|
|
|
|
2019-05-29 18:46:57 +03:00
|
|
|
status := nats.CLOSED
|
|
|
|
if n.conn != nil {
|
|
|
|
status = n.conn.Status()
|
|
|
|
}
|
|
|
|
|
|
|
|
switch status {
|
|
|
|
case nats.CONNECTED, nats.RECONNECTING, nats.CONNECTING:
|
|
|
|
return nil
|
|
|
|
default: // DISCONNECTED or CLOSED or DRAINING
|
|
|
|
opts := n.nopts
|
|
|
|
opts.Servers = n.addrs
|
|
|
|
opts.Secure = n.opts.Secure
|
|
|
|
opts.TLSConfig = n.opts.TLSConfig
|
|
|
|
|
|
|
|
// secure might not be set
|
|
|
|
if n.opts.TLSConfig != nil {
|
|
|
|
opts.Secure = true
|
|
|
|
}
|
|
|
|
|
|
|
|
c, err := opts.Connect()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
n.conn = c
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) Disconnect() error {
|
|
|
|
n.RLock()
|
2019-08-07 12:58:45 +03:00
|
|
|
defer n.RUnlock()
|
2020-01-14 16:23:16 +03:00
|
|
|
|
|
|
|
// drain the connection if specified
|
2019-05-29 18:46:57 +03:00
|
|
|
if n.drain {
|
|
|
|
n.conn.Drain()
|
2020-02-11 18:46:50 +03:00
|
|
|
n.closeCh <- nil
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
|
|
|
|
// close the client connection
|
2019-08-07 12:58:45 +03:00
|
|
|
n.conn.Close()
|
2020-01-14 16:23:16 +03:00
|
|
|
|
|
|
|
// shutdown the local server
|
|
|
|
// and deregister
|
|
|
|
if n.server != nil {
|
|
|
|
select {
|
|
|
|
case <-n.exit:
|
|
|
|
default:
|
|
|
|
close(n.exit)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// set not connected
|
|
|
|
n.connected = false
|
|
|
|
|
2019-05-29 18:46:57 +03:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) Init(opts ...broker.Option) error {
|
2019-08-07 12:58:45 +03:00
|
|
|
n.setOption(opts...)
|
2019-05-29 18:46:57 +03:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) Options() broker.Options {
|
|
|
|
return n.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) 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 *natsBroker) Subscribe(topic string, handler broker.Handler, opts ...broker.SubscribeOption) (broker.Subscriber, error) {
|
|
|
|
if n.conn == nil {
|
|
|
|
return nil, errors.New("not connected")
|
|
|
|
}
|
|
|
|
|
|
|
|
opt := broker.SubscribeOptions{
|
|
|
|
AutoAck: true,
|
|
|
|
Context: context.Background(),
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&opt)
|
|
|
|
}
|
|
|
|
|
|
|
|
fn := func(msg *nats.Msg) {
|
|
|
|
var m broker.Message
|
|
|
|
if err := n.opts.Codec.Unmarshal(msg.Data, &m); err != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
handler(&publication{m: &m, t: msg.Subject})
|
|
|
|
}
|
|
|
|
|
|
|
|
var sub *nats.Subscription
|
|
|
|
var err error
|
|
|
|
|
|
|
|
n.RLock()
|
|
|
|
if len(opt.Queue) > 0 {
|
|
|
|
sub, err = n.conn.QueueSubscribe(topic, opt.Queue, fn)
|
|
|
|
} else {
|
|
|
|
sub, err = n.conn.Subscribe(topic, fn)
|
|
|
|
}
|
|
|
|
n.RUnlock()
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2019-08-07 12:58:45 +03:00
|
|
|
return &subscriber{s: sub, opts: opt}, nil
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) String() string {
|
|
|
|
return "nats"
|
|
|
|
}
|
|
|
|
|
2019-08-07 12:58:45 +03:00
|
|
|
func (n *natsBroker) setOption(opts ...broker.Option) {
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&n.opts)
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
2019-08-07 12:58:45 +03:00
|
|
|
n.Once.Do(func() {
|
|
|
|
n.nopts = nats.GetDefaultOptions()
|
|
|
|
})
|
|
|
|
|
|
|
|
if nopts, ok := n.opts.Context.Value(optionsKey{}).(nats.Options); ok {
|
|
|
|
n.nopts = nopts
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
local, ok := n.opts.Context.Value(localServerKey{}).(bool)
|
|
|
|
if ok {
|
|
|
|
n.local = local
|
|
|
|
}
|
|
|
|
|
2019-05-29 18:46:57 +03:00
|
|
|
// broker.Options have higher priority than nats.Options
|
|
|
|
// only if Addrs, Secure or TLSConfig were not set through a broker.Option
|
|
|
|
// we read them from nats.Option
|
2020-01-14 16:23:16 +03:00
|
|
|
if len(n.opts.Addrs) == 0 && !n.local {
|
2019-08-07 12:58:45 +03:00
|
|
|
n.opts.Addrs = n.nopts.Servers
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
2019-08-07 12:58:45 +03:00
|
|
|
if !n.opts.Secure {
|
|
|
|
n.opts.Secure = n.nopts.Secure
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
|
2019-08-07 12:58:45 +03:00
|
|
|
if n.opts.TLSConfig == nil {
|
|
|
|
n.opts.TLSConfig = n.nopts.TLSConfig
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
n.addrs = n.setAddrs(n.opts.Addrs)
|
2019-08-07 12:58:45 +03:00
|
|
|
|
|
|
|
if n.opts.Context.Value(drainConnectionKey{}) != nil {
|
|
|
|
n.drain = true
|
|
|
|
n.closeCh = make(chan error)
|
|
|
|
n.nopts.ClosedCB = n.onClose
|
|
|
|
n.nopts.AsyncErrorCB = n.onAsyncError
|
2020-02-11 18:46:50 +03:00
|
|
|
n.nopts.DisconnectedErrCB = n.onDisconnectedError
|
2019-08-07 12:58:45 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (n *natsBroker) onClose(conn *nats.Conn) {
|
|
|
|
n.closeCh <- nil
|
|
|
|
}
|
2019-05-29 18:46:57 +03:00
|
|
|
|
2019-08-07 12:58:45 +03:00
|
|
|
func (n *natsBroker) onAsyncError(conn *nats.Conn, sub *nats.Subscription, err error) {
|
|
|
|
// There are kinds of different async error nats might callback, but we are interested
|
|
|
|
// in ErrDrainTimeout only here.
|
|
|
|
if err == nats.ErrDrainTimeout {
|
|
|
|
n.closeCh <- err
|
2019-05-29 18:46:57 +03:00
|
|
|
}
|
|
|
|
}
|
2020-01-14 16:23:16 +03:00
|
|
|
|
2020-02-11 18:46:50 +03:00
|
|
|
func (n *natsBroker) onDisconnectedError(conn *nats.Conn, err error) {
|
2020-02-11 21:41:23 +03:00
|
|
|
n.closeCh <- err
|
2020-02-11 18:46:50 +03:00
|
|
|
}
|
|
|
|
|
2020-01-14 16:23:16 +03:00
|
|
|
func NewBroker(opts ...broker.Option) broker.Broker {
|
|
|
|
options := broker.Options{
|
|
|
|
// Default codec
|
|
|
|
Codec: json.Marshaler{},
|
|
|
|
Context: context.Background(),
|
|
|
|
Registry: registry.DefaultRegistry,
|
|
|
|
}
|
|
|
|
|
|
|
|
n := &natsBroker{
|
|
|
|
opts: options,
|
|
|
|
}
|
|
|
|
n.setOption(opts...)
|
|
|
|
|
|
|
|
return n
|
|
|
|
}
|