Description
Package pubsub provides publish and subscribe functionality within a single process.
A message as far as a hub is concerned is defined by a topic, and a data
blob. All subscribers that match the published topic are notified, and have
their callback function called with both the topic and the data blob.
All subscribers get their own goroutine. This way slow consumers do not
slow down the act of publishing, and slow consumers do not inferfere with
other consumers. Subscribers are guaranteed to get the messages that match
their topic matcher in the order that the messages were published to the
hub.
StructuredHub allows the publisher and subscribers to use structures for data.
structured pubsub alternatives and similar packages
Based on the "Messaging" category.
Alternatively, view structured pubsub alternatives based on common mentions on social networks and blogs.
-
sarama
DISCONTINUED. Sarama is a Go library for Apache Kafka. [Moved to: https://github.com/IBM/sarama] -
Centrifugo
Scalable real-time messaging server in a language-agnostic way. Self-hosted alternative to Pubnub, Pusher, Ably. Set up once and forever. -
Benthos
DISCONTINUED. Fancy stream processing made operationally mundane [Moved to: https://github.com/redpanda-data/connect] -
APNs2
⚡ HTTP/2 Apple Push Notification Service (APNs) push provider for Go — Send push notifications to iOS, tvOS, Safari and OSX apps, using the APNs HTTP/2 protocol. -
Uniqush-Push
Uniqush is a free and open source software system which provides a unified push service for server side notification to apps on mobile devices. -
amqp
An AMQP 0-9-1 Go client maintained by the RabbitMQ team. Originally by @streadway: `streadway/amqp` -
Chanify
Chanify is a safe and simple notification tools. This repository is command line tools for Chanify. -
PingMe
PingMe is a CLI which provides the ability to send messages or alerts to multiple messaging platforms & email. -
emitter
Emits events in Go way, with wildcard, predicates, cancellation possibilities and many other good wins -
Bus
🔊Minimalist message bus implementation for internal communication with zero-allocation magic on Emit -
go-mq
Declare AMQP entities like queues, producers, and consumers in a declarative way. Can be used to work with RabbitMQ. -
Ratus
Ratus is a RESTful asynchronous task queue server. It translated concepts of distributed task queues into a set of resources that conform to REST principles and provides a consistent HTTP API for various backends. -
RapidMQ
RapidMQ is a pure, extremely productive, lightweight and reliable library for managing of the local messages queue
InfluxDB - Purpose built for real-time analytics at any scale.
Do you think we are missing an alternative of structured pubsub or a related project?
README
pubsub
import "github.com/juju/pubsub/v2"
Package pubsub provides publish and subscribe functionality within a single process.
A message as far as a hub is concerned is defined by a topic, and a data blob. All subscribers that match the published topic are notified, and have their callback function called with both the topic and the data blob.
All subscribers get their own goroutine. This way slow consumers do not slow down the act of publishing, and slow consumers do not inferfere with other consumers. Subscribers are guaranteed to get the messages that match their topic matcher in the order that the messages were published to the hub.
This package defines two types of hubs.
- Simple hubs
- Structured hubs
Simple hubs just pass the datablob to the subscribers untouched.
Structuctured hubs will serialize the datablob into a
map[string]interface{}
using the marshaller that was defined to create
it. The subscription handler functions for structured hubs allow the
handlers to define a structure for the datablob to be marshalled into.
Hander functions for a structured hub can get all the published data available by defining a callback with the signature:
func (Topic, map[string]interface{})
Or alternatively, define a struct type, and use that type as the second argument.
func (Topic, SomeStruct, error)
The structured hub will try to serialize the published information into the struct specified. If there is an error marshalling, that error is passed to the callback as the error parameter.
Variables
var JSONMarshaller = &jsonMarshaller{}
JSONMarshaller simply wraps the json.Marshal and json.Unmarshal calls for the Marshaller interface.
type Marshaller
type Marshaller interface {
// Marshal converts the argument into a byte streem that it can then Unmarshal.
Marshal(interface{}) ([]byte, error)
// Unmarshal attempts to convert the byte stream into type passed in as the
// second arg.
Unmarshal([]byte, interface{}) error
}
Marshaller defines the Marshal and Unmarshal methods used to serialize and deserialize the structures used in Publish and Subscription handlers of the structured hub.
type Multiplexer
type Multiplexer interface {
TopicMatcher
Add(matcher TopicMatcher, handler interface{}) error
}
Multiplexer allows multiple subscriptions to be made sharing a single message queue from the hub. This means that all the messages for the various subscriptions are called back in the order that the messages were published. If more than one handler is added to the Multiplexer that matches any given topic, the handlers are called back one after the other in the order that they were added.
type RegexpMatcher
type RegexpMatcher regexp.Regexp
RegexpMatcher allows standard regular expressions to be used as TopicMatcher values. RegexpMatches can be created using the short-hand function MatchRegexp function that wraps regexp.MustCompile.
func (*RegexpMatcher) Match
func (m *RegexpMatcher) Match(topic Topic) bool
Match implements TopicMatcher.
The topic matches if the regular expression matches the topic.
type SimpleHub
type SimpleHub struct {
// contains filtered or unexported fields
}
SimpleHub provides the base functionality of dealing with subscribers, and the notification of subscribers of events.
func NewSimpleHub
func NewSimpleHub(config *SimpleHubConfig) *SimpleHub
NewSimpleHub returns a new SimpleHub instance.
A simple hub does not touch the data that is passed through to Publish. This data is passed through to each Subscriber. Note that all subscribers are notified in parallel, and that no modification should be done to the data or data races will occur.
func (*SimpleHub) Publish
func (h *SimpleHub) Publish(topic Topic, data interface{}) <-chan struct{}
Publish will notifiy all the subscribers that are interested by calling their handler function.
The data is passed through to each Subscriber untouched. Note that all subscribers are notified in parallel, and that no modification should be done to the data or data races will occur.
The channel return value is closed when all the subscribers have been notified of the event.
func (*SimpleHub) Subscribe
func (h *SimpleHub) Subscribe(matcher TopicMatcher, handler func(Topic, interface{})) Unsubscriber
Subscribe takes a topic matcher, and a handler function. If the matcher matches the published topic, the handler function is called with the published Topic and the associated data.
The handler function will be called with all maching published events until the Unsubscribe method on the Unsubscriber is called.
type SimpleHubConfig
type SimpleHubConfig struct {
// LogModule allows for overriding the default logging module.
// The default value is "pubsub.simple".
LogModule string
}
SimpleHubConfig is the argument struct for NewSimpleHub.
type StructuredHub
type StructuredHub struct {
// contains filtered or unexported fields
}
StructuredHub allows the hander functions to accept either structures or map[string]interface{}. The published structure does not need to match the structures of the subscribers. The structures are marshalled using the Marshaller defined in the StructuredHubConfig. If one is not specified, the marshalling is handled by the standard json library.
func NewStructuredHub
func NewStructuredHub(config *StructuredHubConfig) *StructuredHub
NewStructuredHub returns a new StructuredHub instance.
func (*StructuredHub) NewMultiplexer
func (h *StructuredHub) NewMultiplexer() (Unsubscriber, Multiplexer, error)
NewMultiplexer creates a new multiplexer for the hub and subscribes it. Unsubscribing the multiplexer stops calls for all handlers added. Only structured hubs support multiplexer.
func (*StructuredHub) Publish
func (h *StructuredHub) Publish(topic Topic, data interface{}) (<-chan struct{}, error)
Publish will notifiy all the subscribers that are interested by calling their handler function.
The data is serialized out using the marshaller and then back into a map[string]interface{}. If there is an error marshalling the data, Publish fails with an error. The resulting map is then updated with any annotations provided. The annotated values are only set if the specified field is missing or empty. After the annotations are set, the PostProcess function is called if one was specified. The resulting map is then passed to each of the subscribers.
Subscribers are notified in parallel, and that no modification should be done to the data or data races will occur.
The channel return value is closed when all the subscribers have been notified of the event.
func (*StructuredHub) Subscribe
func (h *StructuredHub) Subscribe(matcher TopicMatcher, handler interface{}) (Unsubscriber, error)
Subscribe takes a topic matcher, and a handler function. If the matcher matches the published topic, the handler function is called with the published Topic and the associated data.
The handler function will be called with all maching published events until the Unsubscribe method on the Unsubscriber is called.
The hander function must have the signature:
`func(Topic, map[string]interface{})`
or
`func(Topic, SomeStruct, error)`
where SomeStruct
is any structure. The map[string]interface{} from the
Publish call is unmarshalled into the SomeStruct
structure. If there is
an error unmarshalling the handler is called with a zerod structure and an
error with the marshalling error.
type StructuredHubConfig
type StructuredHubConfig struct {
// LogModule allows for overriding the default logging module.
// The default value is "pubsub.structured".
LogModule string
// Marshaller defines how the structured hub will convert from structures to
// a map[string]interface{} and back. If this is not specified, the
// `JSONMarshaller` is used.
Marshaller Marshaller
// Annotations are added to each message that is published if and only if
// the values are not already set.
Annotations map[string]interface{}
// PostProcess allows the caller to modify the resulting
// map[string]interface{}. This is useful when a dynamic value, such as a
// timestamp is added to the map, or when other type conversions are
// necessary across all the values in the map.
PostProcess func(map[string]interface{}) (map[string]interface{}, error)
}
StructuredHubConfig is the argument struct for NewStructuredHub.
type Topic
type Topic string
Topic represents a message that can be subscribed to.
func (Topic) Match
func (t Topic) Match(topic Topic) bool
Match implements TopicMatcher. One topic matches another if they are equal.
type TopicMatcher
type TopicMatcher interface {
Match(Topic) bool
}
TopicMatcher defines the Match method that is used to determine if the subscriber should be notified about a particular message.
var MatchAll TopicMatcher = (*allMatcher)(nil)
MatchAll is a topic matcher that matches all topics.
func MatchRegexp
func MatchRegexp(expression string) TopicMatcher
MatchRegexp expects a valid regular expression. If the expression passed in is not valid, the function panics. The expected use of this is to be able to do something like:
hub.Subscribe(pubsub.MatchRegex("prefix.*suffix"), handler)
type Unsubscriber
type Unsubscriber interface {
Unsubscribe()
}
Unsubscriber provides a way to stop receiving handler callbacks. Unsubscribing from a hub will also mark any pending notifications as done, and the handler will not be called for them.
Generated by godoc2md