mirror of
https://github.com/mainflux/mainflux.git
synced 2025-04-24 13:48:49 +08:00

* Replace Nats with Nats Jestream For PubSub Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Add Stream Description Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Fix connection leak in NATS publisher The publisher struct in pkg/messaging/nats/publisher.go was modified to include a new `conn` field of type `*broker.Conn`. This change was made to fix a connection leak issue in the NATS publisher. The `NewPublisher` function was updated to assign the `conn` parameter to the new `conn` field in the publisher struct. Additionally, the `Close` method in the publisher struct was modified to close the `conn` connection. This commit fixes the connection leak issue in the NATS publisher and ensures that connections are properly closed. Signed-off-by: Rodney Osodo <socials@rodneyosodo.com> * Setup subscriber config to contain handler topic and ID Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Add delivery policy Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Avoid duplicate messages Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Rename to DeliveryPolicy Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Fix tests Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Not check for data result set when we are returning subset of messages Signed-off-by: Rodney Osodo <socials@rodneyosodo.com> Signed-off-by: Rodney Osodo <28790446+rodneyosodo@users.noreply.github.com> * For unsubscribe remove config Signed-off-by: Rodney Osodo <28790446+rodneyosodo@users.noreply.github.com> * Fix comment Signed-off-by: rodneyosodo <blackd0t@protonmail.com> --------- Signed-off-by: rodneyosodo <blackd0t@protonmail.com> Signed-off-by: Rodney Osodo <socials@rodneyosodo.com> Signed-off-by: Rodney Osodo <28790446+rodneyosodo@users.noreply.github.com>
181 lines
3.9 KiB
Go
181 lines
3.9 KiB
Go
// Copyright (c) Mainflux
|
|
// SPDX-License-Identifier: Apache-2.0
|
|
|
|
package rabbitmq
|
|
|
|
import (
|
|
"context"
|
|
"errors"
|
|
"fmt"
|
|
"sync"
|
|
|
|
mflog "github.com/mainflux/mainflux/logger"
|
|
"github.com/mainflux/mainflux/pkg/messaging"
|
|
amqp "github.com/rabbitmq/amqp091-go"
|
|
"google.golang.org/protobuf/proto"
|
|
)
|
|
|
|
const (
|
|
chansPrefix = "channels"
|
|
// SubjectAllChannels represents subject to subscribe for all the channels.
|
|
SubjectAllChannels = "channels.#"
|
|
exchangeName = "mainflux"
|
|
)
|
|
|
|
var (
|
|
// ErrNotSubscribed indicates that the topic is not subscribed to.
|
|
ErrNotSubscribed = errors.New("not subscribed")
|
|
|
|
// ErrEmptyTopic indicates the absence of topic.
|
|
ErrEmptyTopic = errors.New("empty topic")
|
|
|
|
// ErrEmptyID indicates the absence of ID.
|
|
ErrEmptyID = errors.New("empty ID")
|
|
)
|
|
var _ messaging.PubSub = (*pubsub)(nil)
|
|
|
|
type subscription struct {
|
|
cancel func() error
|
|
}
|
|
type pubsub struct {
|
|
publisher
|
|
logger mflog.Logger
|
|
subscriptions map[string]map[string]subscription
|
|
mu sync.Mutex
|
|
}
|
|
|
|
// NewPubSub returns RabbitMQ message publisher/subscriber.
|
|
func NewPubSub(url string, logger mflog.Logger) (messaging.PubSub, error) {
|
|
conn, err := amqp.Dial(url)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
ch, err := conn.Channel()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
if err := ch.ExchangeDeclare(exchangeName, amqp.ExchangeTopic, true, false, false, false, nil); err != nil {
|
|
return nil, err
|
|
}
|
|
ret := &pubsub{
|
|
publisher: publisher{
|
|
conn: conn,
|
|
ch: ch,
|
|
},
|
|
logger: logger,
|
|
subscriptions: make(map[string]map[string]subscription),
|
|
}
|
|
return ret, nil
|
|
}
|
|
|
|
func (ps *pubsub) Subscribe(ctx context.Context, cfg messaging.SubscriberConfig) error {
|
|
if cfg.ID == "" {
|
|
return ErrEmptyID
|
|
}
|
|
if cfg.Topic == "" {
|
|
return ErrEmptyTopic
|
|
}
|
|
ps.mu.Lock()
|
|
|
|
cfg.Topic = formatTopic(cfg.Topic)
|
|
// Check topic
|
|
s, ok := ps.subscriptions[cfg.Topic]
|
|
if ok {
|
|
// Check client ID
|
|
if _, ok := s[cfg.ID]; ok {
|
|
// Unlocking, so that Unsubscribe() can access ps.subscriptions
|
|
ps.mu.Unlock()
|
|
if err := ps.Unsubscribe(ctx, cfg.ID, cfg.Topic); err != nil {
|
|
return err
|
|
}
|
|
|
|
ps.mu.Lock()
|
|
// value of s can be changed while ps.mu is unlocked
|
|
s = ps.subscriptions[cfg.Topic]
|
|
}
|
|
}
|
|
defer ps.mu.Unlock()
|
|
if s == nil {
|
|
s = make(map[string]subscription)
|
|
ps.subscriptions[cfg.Topic] = s
|
|
}
|
|
|
|
clientID := fmt.Sprintf("%s-%s", cfg.Topic, cfg.ID)
|
|
|
|
queue, err := ps.ch.QueueDeclare(clientID, true, false, false, false, nil)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if err := ps.ch.QueueBind(queue.Name, cfg.Topic, exchangeName, false, nil); err != nil {
|
|
return err
|
|
}
|
|
|
|
msgs, err := ps.ch.Consume(queue.Name, clientID, true, false, false, false, nil)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
go ps.handle(msgs, cfg.Handler)
|
|
s[cfg.ID] = subscription{
|
|
cancel: func() error {
|
|
if err := ps.ch.Cancel(clientID, false); err != nil {
|
|
return err
|
|
}
|
|
return cfg.Handler.Cancel()
|
|
},
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
func (ps *pubsub) Unsubscribe(ctx context.Context, id, topic string) error {
|
|
if id == "" {
|
|
return ErrEmptyID
|
|
}
|
|
if topic == "" {
|
|
return ErrEmptyTopic
|
|
}
|
|
ps.mu.Lock()
|
|
defer ps.mu.Unlock()
|
|
|
|
topic = formatTopic(topic)
|
|
// Check topic
|
|
s, ok := ps.subscriptions[topic]
|
|
if !ok {
|
|
return ErrNotSubscribed
|
|
}
|
|
// Check topic ID
|
|
current, ok := s[id]
|
|
if !ok {
|
|
return ErrNotSubscribed
|
|
}
|
|
if current.cancel != nil {
|
|
if err := current.cancel(); err != nil {
|
|
return err
|
|
}
|
|
}
|
|
if err := ps.ch.QueueUnbind(topic, topic, exchangeName, nil); err != nil {
|
|
return err
|
|
}
|
|
|
|
delete(s, id)
|
|
if len(s) == 0 {
|
|
delete(ps.subscriptions, topic)
|
|
}
|
|
return nil
|
|
}
|
|
|
|
func (ps *pubsub) handle(deliveries <-chan amqp.Delivery, h messaging.MessageHandler) {
|
|
for d := range deliveries {
|
|
var msg messaging.Message
|
|
if err := proto.Unmarshal(d.Body, &msg); err != nil {
|
|
ps.logger.Warn(fmt.Sprintf("Failed to unmarshal received message: %s", err))
|
|
return
|
|
}
|
|
if err := h.Handle(&msg); err != nil {
|
|
ps.logger.Warn(fmt.Sprintf("Failed to handle Mainflux message: %s", err))
|
|
return
|
|
}
|
|
}
|
|
}
|