2023-05-09 20:04:15 +03:00
|
|
|
//go:build ignore
|
|
|
|
|
2021-02-12 16:33:16 +03:00
|
|
|
package broker
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"sync"
|
2023-04-27 15:30:55 +03:00
|
|
|
"time"
|
2021-02-12 16:33:16 +03:00
|
|
|
|
2023-04-11 22:20:37 +03:00
|
|
|
"go.unistack.org/micro/v4/logger"
|
|
|
|
maddr "go.unistack.org/micro/v4/util/addr"
|
|
|
|
"go.unistack.org/micro/v4/util/id"
|
|
|
|
mnet "go.unistack.org/micro/v4/util/net"
|
|
|
|
"go.unistack.org/micro/v4/util/rand"
|
2021-02-12 16:33:16 +03:00
|
|
|
)
|
|
|
|
|
|
|
|
type memoryBroker struct {
|
2021-07-23 15:12:20 +03:00
|
|
|
subscribers map[string][]*memorySubscriber
|
|
|
|
addr string
|
|
|
|
opts Options
|
2021-03-06 19:45:13 +03:00
|
|
|
sync.RWMutex
|
|
|
|
connected bool
|
2021-02-12 16:33:16 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Options() Options {
|
|
|
|
return m.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Address() string {
|
|
|
|
return m.addr
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Connect(ctx context.Context) error {
|
|
|
|
m.Lock()
|
|
|
|
defer m.Unlock()
|
|
|
|
|
|
|
|
if m.connected {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// use 127.0.0.1 to avoid scan of all network interfaces
|
|
|
|
addr, err := maddr.Extract("127.0.0.1")
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-02-17 22:58:55 +03:00
|
|
|
var rng rand.Rand
|
|
|
|
i := rng.Intn(20000)
|
2021-02-12 16:33:16 +03:00
|
|
|
// set addr with port
|
|
|
|
addr = mnet.HostPort(addr, 10000+i)
|
|
|
|
|
|
|
|
m.addr = addr
|
|
|
|
m.connected = true
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Disconnect(ctx context.Context) error {
|
|
|
|
m.Lock()
|
|
|
|
defer m.Unlock()
|
|
|
|
|
|
|
|
if !m.connected {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
m.connected = false
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Init(opts ...Option) error {
|
|
|
|
for _, o := range opts {
|
|
|
|
o(&m.opts)
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryBroker) NewMessage(endpoint string, req interface{}, opts ...MessageOption) Message {
|
|
|
|
return &memoryMessage{}
|
2021-07-23 15:06:10 +03:00
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryBroker) Publish(ctx context.Context, message interface{}, opts ...PublishOption) error {
|
2021-07-23 15:06:10 +03:00
|
|
|
m.RLock()
|
|
|
|
if !m.connected {
|
|
|
|
m.RUnlock()
|
|
|
|
return ErrNotConnected
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
2021-07-23 15:06:10 +03:00
|
|
|
m.RUnlock()
|
2021-07-22 22:53:44 +03:00
|
|
|
|
2021-07-23 15:12:20 +03:00
|
|
|
var err error
|
2021-07-22 22:53:44 +03:00
|
|
|
|
2021-09-30 20:32:59 +03:00
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return ctx.Err()
|
|
|
|
default:
|
|
|
|
options := NewPublishOptions(opts...)
|
2023-05-09 20:04:15 +03:00
|
|
|
var msgs []*memoryMessage
|
|
|
|
switch v := message.(type) {
|
|
|
|
case *memoryMessage:
|
|
|
|
msgs = []*memoryMessage{v}
|
|
|
|
case []*memoryMessage:
|
|
|
|
msgs = v
|
|
|
|
default:
|
|
|
|
return ErrInvalidMessage
|
|
|
|
}
|
|
|
|
msgTopicMap := make(map[string][]*memoryMessage)
|
|
|
|
for _, msg := range msgs {
|
|
|
|
p := &memoryMessage{opts: options}
|
|
|
|
/*
|
|
|
|
if mb, ok := msg.Body().(*codec.Frame); ok {
|
|
|
|
p.message = v.Body
|
|
|
|
} else {
|
|
|
|
p.topic, _ = v.Header.Get(metadata.HeaderTopic)
|
|
|
|
p.message, err = m.opts.Codec.Marshal(v)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-09-30 20:32:59 +03:00
|
|
|
}
|
2023-05-09 20:04:15 +03:00
|
|
|
*/
|
|
|
|
msgTopicMap[msg.Topic()] = append(msgTopicMap[p.topic], p)
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
|
|
|
|
2021-09-30 20:32:59 +03:00
|
|
|
eh := m.opts.ErrorHandler
|
2021-07-23 15:12:20 +03:00
|
|
|
|
2021-09-30 20:32:59 +03:00
|
|
|
for t, ms := range msgTopicMap {
|
2023-04-27 15:30:55 +03:00
|
|
|
ts := time.Now()
|
|
|
|
|
|
|
|
m.opts.Meter.Counter(PublishMessageInflight, "endpoint", t).Add(len(ms))
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageInflight, "endpoint", t).Add(len(ms))
|
|
|
|
|
2021-09-30 20:32:59 +03:00
|
|
|
m.RLock()
|
|
|
|
subs, ok := m.subscribers[t]
|
|
|
|
m.RUnlock()
|
|
|
|
if !ok {
|
2023-04-27 15:30:55 +03:00
|
|
|
m.opts.Meter.Counter(PublishMessageTotal, "endpoint", t, "status", "failure").Add(len(ms))
|
|
|
|
m.opts.Meter.Counter(PublishMessageInflight, "endpoint", t).Add(-len(ms))
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageInflight, "endpoint", t).Add(-len(ms))
|
2021-09-30 20:32:59 +03:00
|
|
|
continue
|
2021-09-29 13:10:11 +03:00
|
|
|
}
|
|
|
|
|
2023-04-27 15:30:55 +03:00
|
|
|
m.opts.Meter.Counter(PublishMessageTotal, "endpoint", t, "status", "success").Add(len(ms))
|
2021-09-30 20:32:59 +03:00
|
|
|
for _, sub := range subs {
|
|
|
|
if sub.opts.ErrorHandler != nil {
|
|
|
|
eh = sub.opts.ErrorHandler
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
for _, p := range ms {
|
|
|
|
if err = sub.handler(p); err != nil {
|
2023-04-27 15:30:55 +03:00
|
|
|
m.opts.Meter.Counter(SubscribeMessageTotal, "endpoint", t, "status", "failure").Inc()
|
2023-05-09 20:04:15 +03:00
|
|
|
if eh != nil {
|
|
|
|
_ = eh(p)
|
2021-07-23 15:12:20 +03:00
|
|
|
} else if m.opts.Logger.V(logger.ErrorLevel) {
|
|
|
|
m.opts.Logger.Error(m.opts.Context, err.Error())
|
|
|
|
}
|
2023-04-27 15:30:55 +03:00
|
|
|
} else {
|
|
|
|
if sub.opts.AutoAck {
|
2023-05-09 20:04:15 +03:00
|
|
|
if err = p.Ack(); err != nil {
|
2023-04-27 15:30:55 +03:00
|
|
|
m.opts.Logger.Errorf(m.opts.Context, "ack failed: %v", err)
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageTotal, "endpoint", t, "status", "failure").Inc()
|
|
|
|
} else {
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageTotal, "endpoint", t, "status", "success").Inc()
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageTotal, "endpoint", t, "status", "success").Inc()
|
2021-07-23 15:12:20 +03:00
|
|
|
}
|
|
|
|
}
|
2023-05-09 20:04:15 +03:00
|
|
|
m.opts.Meter.Counter(PublishMessageInflight, "endpoint", t).Add(-1)
|
|
|
|
m.opts.Meter.Counter(SubscribeMessageInflight, "endpoint", t).Add(-1)
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
2023-04-27 15:30:55 +03:00
|
|
|
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
2023-04-27 15:30:55 +03:00
|
|
|
te := time.Since(ts)
|
|
|
|
m.opts.Meter.Summary(PublishMessageLatencyMicroseconds, "endpoint", t).Update(te.Seconds())
|
|
|
|
m.opts.Meter.Histogram(PublishMessageDurationSeconds, "endpoint", t).Update(te.Seconds())
|
|
|
|
m.opts.Meter.Summary(SubscribeMessageLatencyMicroseconds, "endpoint", t).Update(te.Seconds())
|
|
|
|
m.opts.Meter.Histogram(SubscribeMessageDurationSeconds, "endpoint", t).Update(te.Seconds())
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
2023-04-27 15:30:55 +03:00
|
|
|
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryBroker) Subscribe(ctx context.Context, topic string, handler interface{}, opts ...SubscribeOption) (Subscriber, error) {
|
2021-02-12 16:33:16 +03:00
|
|
|
m.RLock()
|
|
|
|
if !m.connected {
|
|
|
|
m.RUnlock()
|
2021-07-22 22:53:44 +03:00
|
|
|
return nil, ErrNotConnected
|
2021-02-12 16:33:16 +03:00
|
|
|
}
|
|
|
|
m.RUnlock()
|
|
|
|
|
2021-08-20 22:40:48 +03:00
|
|
|
sid, err := id.New()
|
2021-02-12 16:33:16 +03:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2021-07-23 15:06:10 +03:00
|
|
|
options := NewSubscribeOptions(opts...)
|
|
|
|
|
2021-02-12 16:33:16 +03:00
|
|
|
sub := &memorySubscriber{
|
|
|
|
exit: make(chan bool, 1),
|
2021-08-20 22:40:48 +03:00
|
|
|
id: sid,
|
2021-02-12 16:33:16 +03:00
|
|
|
topic: topic,
|
|
|
|
handler: handler,
|
|
|
|
opts: options,
|
|
|
|
ctx: ctx,
|
|
|
|
}
|
|
|
|
|
|
|
|
m.Lock()
|
2021-07-22 22:53:44 +03:00
|
|
|
m.subscribers[topic] = append(m.subscribers[topic], sub)
|
2021-02-12 16:33:16 +03:00
|
|
|
m.Unlock()
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
<-sub.exit
|
|
|
|
m.Lock()
|
2021-07-23 15:06:10 +03:00
|
|
|
newSubscribers := make([]*memorySubscriber, 0, len(m.subscribers)-1)
|
2021-07-22 22:53:44 +03:00
|
|
|
for _, sb := range m.subscribers[topic] {
|
2021-02-12 16:33:16 +03:00
|
|
|
if sb.id == sub.id {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
newSubscribers = append(newSubscribers, sb)
|
|
|
|
}
|
2021-07-22 22:53:44 +03:00
|
|
|
m.subscribers[topic] = newSubscribers
|
2021-02-12 16:33:16 +03:00
|
|
|
m.Unlock()
|
|
|
|
}()
|
|
|
|
|
|
|
|
return sub, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) String() string {
|
|
|
|
return "memory"
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memoryBroker) Name() string {
|
|
|
|
return m.opts.Name
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
type memoryMessage struct {
|
|
|
|
err error
|
|
|
|
body interface{}
|
|
|
|
topic string
|
|
|
|
opts PublishOptions
|
|
|
|
ctx context.Context
|
2021-02-12 16:33:16 +03:00
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryMessage) Topic() string {
|
|
|
|
return m.topic
|
|
|
|
}
|
2021-02-12 16:33:16 +03:00
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryMessage) Body() interface{} {
|
|
|
|
return m.body
|
2021-02-12 16:33:16 +03:00
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryMessage) Ack() error {
|
2021-02-12 16:33:16 +03:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryMessage) Error() error {
|
2021-02-12 16:33:16 +03:00
|
|
|
return m.err
|
|
|
|
}
|
|
|
|
|
2023-05-09 20:04:15 +03:00
|
|
|
func (m *memoryMessage) Context() context.Context {
|
|
|
|
return m.ctx
|
|
|
|
}
|
|
|
|
|
|
|
|
type memorySubscriber struct {
|
|
|
|
ctx context.Context
|
|
|
|
exit chan bool
|
|
|
|
handler interface{}
|
|
|
|
id string
|
|
|
|
topic string
|
|
|
|
opts SubscribeOptions
|
2021-07-22 22:53:44 +03:00
|
|
|
}
|
|
|
|
|
2021-02-12 16:33:16 +03:00
|
|
|
func (m *memorySubscriber) Options() SubscribeOptions {
|
|
|
|
return m.opts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memorySubscriber) Topic() string {
|
|
|
|
return m.topic
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *memorySubscriber) Unsubscribe(ctx context.Context) error {
|
|
|
|
m.exit <- true
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2021-02-13 15:35:56 +03:00
|
|
|
// NewBroker return new memory broker
|
2023-05-09 20:04:15 +03:00
|
|
|
func NewBroker(opts ...Option) *memoryBroker {
|
2021-02-12 16:33:16 +03:00
|
|
|
return &memoryBroker{
|
2021-07-23 15:12:20 +03:00
|
|
|
opts: NewOptions(opts...),
|
|
|
|
subscribers: make(map[string][]*memorySubscriber),
|
2021-02-12 16:33:16 +03:00
|
|
|
}
|
|
|
|
}
|