Documentation
¶
Overview ¶
Package pubsub provides an easy and portable way to interact with publish/ subscribe systems. See https://gocloud.dev/howto/pubsub/ for how-to guides.
Subpackages contain distinct implementations of pubsub for various providers, including Cloud and on-prem solutions. For example, "gcppubsub" supports Google Cloud Pub/Sub. Your application should import one of these provider-specific subpackages and use its exported functions to get a *Topic and/or *Subscription; do not use the NewTopic/NewSubscription functions in this package. For example:
topic := mempubsub.NewTopic() err := topic.Send(ctx.Background(), &pubsub.Message{Body: []byte("hi")) ...
Then, write your application code using the *Topic/*Subscription types. You can easily reconfigure your initialization code to choose a different provider. You can develop your application locally using memblob, or deploy it to multiple Cloud providers. You may find http://github.com/google/wire useful for managing your initialization code.
Alternatively, you can construct a *Topic/*Subscription via a URL and OpenTopic/OpenSubscription. See https://godoc.org/gocloud.dev#hdr-URLs for more information.
At-most-once and At-least-once Delivery ¶
Some PubSub systems guarantee that messages received by subscribers but not acknowledged are delivered again. These at-least-once systems require that subscribers call an Ack function to indicate that they have fully processed a message.
In other PubSub systems, a message will be delivered only once, if it is delivered at all. These at-most-once systems do not need subscribers to Ack; the message is essentially auto-acked when it is delivered.
This package accommodates both kinds of systems. See the provider-specific package documentation to see whether it is at-most-once or at-least-once. Some providers support both modes.
Application developers should think carefully about which kind of semantics the application needs. Even though the application code may look similar, the system-level characteristics are quite different.
After receiving a Message via Subscription.Receive:
- If your application ever uses an at-least-once provider, it should always call Message.Ack/Nack after processing a message.
- If your application only uses at-most-once providers, you can omit the call to Message.Ack. It should never call Message.Nack, as that operation doesn't make sense for an at-most-once system.
The Subscription constructor for at-most-once-providers will require a function that will be called whenever the application calls Message.Ack. This forces the application developer to be explicit about what happens when Ack is called, since the provider has no meaningful implementation. Common function to supply are:
- func() {}: Do nothing. Use this if your application does call Message.Ack; it makes explicit that Ack for the provider is a no-op.
- func() { panic("ack called!") }: panic. This is appropriate if your application only uses at-most-once providers and you don't expect it to ever call Message.Ack.
- func() { log.Info("ack called!") }: log. Softer than panicking.
Since Message.Nack never makes sense for at-most-once providers (the provider can't redeliver the message), Nack will always panic if called for at-most-once providers.
OpenCensus Integration ¶
OpenCensus supports tracing and metric collection for multiple languages and backend providers. See https://opencensus.io.
This API collects OpenCensus traces and metrics for the following methods:
- Topic.Send
- Topic.Shutdown
- Subscription.Receive
- Subscription.Shutdown
- The internal driver methods SendBatch, SendAcks and ReceiveBatch.
All trace and metric names begin with the package import path. The traces add the method name. For example, "gocloud.dev/pubsub/Topic.Send". The metrics are "completed_calls", a count of completed method calls by provider, method and status (error code); and "latency", a distribution of method latency by provider and method. For example, "gocloud.dev/pubsub/latency".
To enable trace collection in your application, see "Configure Exporter" at https://opencensus.io/quickstart/go/tracing. To enable metric collection in your application, see "Exporting stats" at https://opencensus.io/quickstart/go/metrics.
Example (ReceiveWithInvertedWorkerPool) ¶
package main import ( "context" "fmt" "log" "sync" "time" "gocloud.dev/pubsub" "gocloud.dev/pubsub/mempubsub" ) func main() { // Open a topic and corresponding subscription. ctx := context.Background() t := mempubsub.NewTopic() defer t.Shutdown(ctx) s := mempubsub.NewSubscription(t, time.Second) defer s.Shutdown(ctx) // Send a bunch of messages to the topic. const nMessages = 100 for n := 0; n < nMessages; n++ { m := &pubsub.Message{ Body: []byte(fmt.Sprintf("message %d", n)), } if err := t.Send(ctx, m); err != nil { log.Fatal(err) } } // In order to make our test exit, we keep track of how many messages were // processed with wg, and cancel the receiveCtx when we've processed them all. // A more realistic application would not need this WaitGroup. var wg sync.WaitGroup wg.Add(nMessages) receiveCtx, cancel := context.WithCancel(ctx) go func() { wg.Wait() cancel() }() // Process messages using an inverted worker pool, as described here: // https://www.youtube.com/watch?v=5zXAHh5tJqQ&t=26m58s // It uses a buffered channel, sem, as a semaphore to manage the maximum // number of workers. const poolSize = 10 sem := make(chan struct{}, poolSize) for { // Read a message. Receive will block until a message is available. msg, err := s.Receive(receiveCtx) if err != nil { // An error from Receive is fatal; Receive will never succeed again // so the application should exit. // In this example, we expect to get a error here when we've read all the // messages and receiveCtx is canceled. break } // Write a token to the semaphore; if there are already poolSize workers // active, this will block until one of them completes. sem <- struct{}{} // Process the message. For many applications, this can be expensive, so // we do it in a goroutine, allowing this loop to continue and Receive more // messages. go func() { // Record that we've processed this message, and Ack it. msg.Ack() wg.Done() // Read a token from the semaphore before exiting this goroutine, freeing // up the slot for another goroutine. <-sem }() } // Wait for all workers to finish. for n := poolSize; n > 0; n-- { sem <- struct{}{} } fmt.Printf("Read %d messages", nMessages) }
Output: Read 100 messages
Example (ReceiveWithTraditionalWorkerPool) ¶
package main import ( "context" "fmt" "log" "sync" "time" "gocloud.dev/pubsub" "gocloud.dev/pubsub/mempubsub" ) func main() { // Open a topic and corresponding subscription. ctx := context.Background() t := mempubsub.NewTopic() defer t.Shutdown(ctx) s := mempubsub.NewSubscription(t, time.Second) defer s.Shutdown(ctx) // Send a bunch of messages to the topic. const nMessages = 100 for n := 0; n < nMessages; n++ { m := &pubsub.Message{ Body: []byte(fmt.Sprintf("message %d", n)), } if err := t.Send(ctx, m); err != nil { log.Fatal(err) } } // In order to make our test exit, we keep track of how many messages were // processed with wg, and cancel the receiveCtx when we've processed them all. // A more realistic application would not need this WaitGroup. var wg sync.WaitGroup wg.Add(nMessages) receiveCtx, cancel := context.WithCancel(ctx) go func() { wg.Wait() cancel() }() // Process messages using a traditional worker pool. Consider using an // inverted pool instead (see the other example). const poolSize = 10 var workerWg sync.WaitGroup for n := 0; n < poolSize; n++ { workerWg.Add(1) go func() { for { // Read a message. Receive will block until a message is available. // It's fine to call Receive from many goroutines. msg, err := s.Receive(receiveCtx) if err != nil { // An error from Receive is fatal; Receive will never succeed again // so the application should exit. // In this example, we expect to get a error here when we've read all // the messages and receiveCtx is canceled. workerWg.Done() return } // Process the message and Ack it. msg.Ack() wg.Done() } }() } // Wait for all workers to finish. workerWg.Wait() fmt.Printf("Read %d messages", nMessages) }
Output: Read 100 messages
Example (SendReceive) ¶
package main import ( "context" "fmt" "log" "time" "gocloud.dev/pubsub" "gocloud.dev/pubsub/mempubsub" ) func main() { // Open a topic and corresponding subscription. ctx := context.Background() t := mempubsub.NewTopic() defer t.Shutdown(ctx) s := mempubsub.NewSubscription(t, time.Second) defer s.Shutdown(ctx) // Send a message to the topic. if err := t.Send(ctx, &pubsub.Message{Body: []byte("Hello, world!")}); err != nil { log.Fatal(err) } // Receive a message from the subscription. m, err := s.Receive(ctx) if err != nil { log.Fatal(err) } // Print out the received message. fmt.Printf("%s\n", m.Body) // Acknowledge the message. m.Ack() }
Output: Hello, world!
Example (SendReceiveMultipleMessages) ¶
package main import ( "context" "fmt" "log" "sort" "time" "gocloud.dev/pubsub" "gocloud.dev/pubsub/mempubsub" ) func main() { // Open a topic and corresponding subscription. ctx := context.Background() t := mempubsub.NewTopic() defer t.Shutdown(ctx) s := mempubsub.NewSubscription(t, time.Second) defer s.Shutdown(ctx) // Send messages to the topic. ms := []*pubsub.Message{ {Body: []byte("a")}, {Body: []byte("b")}, {Body: []byte("c")}, } for _, m := range ms { if err := t.Send(ctx, m); err != nil { log.Fatal(err) } } // Receive and acknowledge messages from the subscription. ms2 := []string{} for i := 0; i < len(ms); i++ { m2, err := s.Receive(ctx) if err != nil { log.Fatal(err) } ms2 = append(ms2, string(m2.Body)) m2.Ack() } // The messages may be received in a different order than they were // sent. sort.Strings(ms2) // Print out the received messages. for _, m2 := range ms2 { fmt.Println(m2) } }
Output: a b c
Index ¶
- Variables
- type Message
- type Subscription
- type SubscriptionURLOpener
- type Topic
- type TopicURLOpener
- type URLMux
- func (mux *URLMux) OpenSubscription(ctx context.Context, urlstr string) (*Subscription, error)
- func (mux *URLMux) OpenSubscriptionURL(ctx context.Context, u *url.URL) (*Subscription, error)
- func (mux *URLMux) OpenTopic(ctx context.Context, urlstr string) (*Topic, error)
- func (mux *URLMux) OpenTopicURL(ctx context.Context, u *url.URL) (*Topic, error)
- func (mux *URLMux) RegisterSubscription(scheme string, opener SubscriptionURLOpener)
- func (mux *URLMux) RegisterTopic(scheme string, opener TopicURLOpener)
- func (mux *URLMux) SubscriptionSchemes() []string
- func (mux *URLMux) TopicSchemes() []string
- func (mux *URLMux) ValidSubscriptionScheme(scheme string) bool
- func (mux *URLMux) ValidTopicScheme(scheme string) bool
Examples ¶
Constants ¶
This section is empty.
Variables ¶
var NewSubscription = newSubscription
NewSubscription is for use by provider implementations.
var NewTopic = newTopic
NewTopic is for use by provider implementations.
var ( // OpenCensusViews are predefined views for OpenCensus metrics. // The views include counts and latency distributions for API method calls. // See the example at https://godoc.org/go.opencensus.io/stats/view for usage. OpenCensusViews = oc.Views(pkgName, latencyMeasure) )
Functions ¶
This section is empty.
Types ¶
type Message ¶
type Message struct { // Body contains the content of the message. Body []byte // Metadata has key/value metadata for the message. It will be nil if the // message has no associated metadata. Metadata map[string]string // contains filtered or unexported fields }
Message contains data to be published.
func (*Message) Ack ¶
func (m *Message) Ack()
Ack acknowledges the message, telling the server that it does not need to be sent again to the associated Subscription. It returns immediately, but the actual ack is sent in the background, and is not guaranteed to succeed.
func (*Message) As ¶ added in v0.10.0
As converts i to provider-specific types. See https://godoc.org/gocloud.dev#hdr-As for background information, the "As" examples in this package for examples, and the provider-specific package documentation for the specific types supported for that provider. As panics unless it is called on a message obtained from Subscription.Receive.
Example ¶
package main import ( "context" "log" "gocloud.dev/pubsub" pbapi "google.golang.org/genproto/googleapis/pubsub/v1" ) func main() { // This example is specific to the gcppubsub implementation; it demonstrates // access to the underlying PubsubMessage type. // The types exposed for As by gcppubsub are documented in // https://godoc.org/gocloud.dev/pubsub/gcppubsub#hdr-As ctx := context.Background() sub, err := pubsub.OpenSubscription(ctx, "gcppubsub://project/topic") if err != nil { log.Fatal(err) } defer sub.Shutdown(ctx) msg, err := sub.Receive(ctx) if err != nil { log.Fatal(err) } var pm *pbapi.PubsubMessage if msg.As(&pm) { _ = pm.GetAttributes() } msg.Ack() }
Output:
func (*Message) Nack ¶ added in v0.13.0
func (m *Message) Nack()
Nack (short for negative acknowledgment) tells the server that this Message was not processed and should be redelivered. It returns immediately, but the actual nack is sent in the background, and is not guaranteed to succeed.
Nack is a performance optimization for retrying transient failures. Nack must not be used for message parse errors or other messages that the application will never be able to process: calling Nack will cause them to be redelivered and overload the server. Instead, an application should call Ack and log the failure in some monitored way.
Nack panics for at-most-once providers, as Nack is meaningless when messages can't be redelivered.
type Subscription ¶
type Subscription struct {
// contains filtered or unexported fields
}
Subscription receives published messages.
func OpenSubscription ¶ added in v0.12.0
func OpenSubscription(ctx context.Context, urlstr string) (*Subscription, error)
OpenSubscription opens the Subscription identified by the URL given. See the URLOpener documentation in provider-specific subpackages for details on supported URL formats, and https://godoc.org/gocloud.dev#hdr-URLs for more information.
func (*Subscription) As ¶
func (s *Subscription) As(i interface{}) bool
As converts i to provider-specific types. See https://godoc.org/gocloud.dev#hdr-As for background information, the "As" examples in this package for examples, and the provider-specific package documentation for the specific types supported for that provider.
Example ¶
package main import ( "context" "log" "gocloud.dev/pubsub" pbraw "cloud.google.com/go/pubsub/apiv1" ) func main() { // This example is specific to the gcppubsub implementation; it demonstrates // access to the underlying SubscriberClient type. // The types exposed for As by gcppubsub are documented in // https://godoc.org/gocloud.dev/pubsub/gcppubsub#hdr-As ctx := context.Background() sub, err := pubsub.OpenSubscription(ctx, "gcppubsub://project/topic") if err != nil { log.Fatal(err) } defer sub.Shutdown(ctx) var sc *pbraw.SubscriberClient if sub.As(&sc) { _ = sc.CallOptions } }
Output:
func (*Subscription) ErrorAs ¶ added in v0.10.0
func (s *Subscription) ErrorAs(err error, i interface{}) bool
ErrorAs converts err to provider-specific types. ErrorAs panics if i is nil or not a pointer. ErrorAs returns false if err == nil. See Topic.As for more details.
Example ¶
package main import ( "context" "log" "gocloud.dev/pubsub" "google.golang.org/grpc/status" ) func main() { // This example is specific to the gcppubsub implementation; it demonstrates // access to the underlying Status type. // The types exposed for As by gcppubsub are documented in // https://godoc.org/gocloud.dev/pubsub/gcppubsub#hdr-As ctx := context.Background() sub, err := pubsub.OpenSubscription(ctx, "gcppubsub://project/badtopic") if err != nil { log.Fatal(err) } defer sub.Shutdown(ctx) msg, err := sub.Receive(ctx) if err != nil { var s *status.Status if sub.ErrorAs(err, &s) { _ = s.Code() } log.Fatal(err) } msg.Ack() }
Output:
func (*Subscription) Receive ¶
func (s *Subscription) Receive(ctx context.Context) (_ *Message, err error)
Receive receives and returns the next message from the Subscription's queue, blocking and polling if none are available. It can be called concurrently from multiple goroutines.
Receive retries retryable errors from the underlying provider forever. Therefore, if Receive returns an error, either:
- It is a non-retryable error from the underlying provider, either from an attempt to fetch more messages or from an attempt to ack messages. Operator intervention may be required (e.g., invalid resource, quota error, etc.). Receive will return the same error from then on, so the application should log the error and either recreate the Subscription, or exit.
- The provided ctx is Done. Error() on the returned error will include both the ctx error and the underyling provider error, and ErrorAs on it can access the underlying provider error type if needed. Receive may be called again with a fresh ctx.
Callers can distinguish between the two by checking if the ctx they passed is Done, or via xerrors.Is(err, context.DeadlineExceeded or context.Canceled) on the returned error.
The Ack method of the returned Message must be called once the message has been processed, to prevent it from being received again, unless only at-most-once providers are being used; see the package doc for more).
type SubscriptionURLOpener ¶ added in v0.12.0
type SubscriptionURLOpener interface {
OpenSubscriptionURL(ctx context.Context, u *url.URL) (*Subscription, error)
}
SubscriptionURLOpener represents types than can open Subscriptions based on a URL. The opener must not modify the URL argument. OpenSubscriptionURL must be safe to call from multiple goroutines.
This interface is generally implemented by types in driver packages.
type Topic ¶
type Topic struct {
// contains filtered or unexported fields
}
Topic publishes messages to all its subscribers.
func OpenTopic ¶ added in v0.12.0
OpenTopic opens the Topic identified by the URL given. See the URLOpener documentation in provider-specific subpackages for details on supported URL formats, and https://godoc.org/gocloud.dev#hdr-URLs for more information.
Example ¶
package main import ( "context" "fmt" "log" "gocloud.dev/pubsub" _ "gocloud.dev/pubsub/mempubsub" ) func main() { ctx := context.Background() // Create a Topic using a URL. // This example uses "mempubsub", the in-memory implementation. // We need to add a blank import line to register the mempubsub provider's // URLOpener, which implements pubsub.TopicURLOpener: // import _ "gocloud.dev/secrets/mempubsub" // mempubsub registers for the "mem" scheme. // All pubsub.OpenTopic URLs also work with "pubsub+" or "pubsub+topic+" prefixes, // e.g., "pubsub+mem://mytopic" or "pubsub+topic+mem://mytopic". topic, err := pubsub.OpenTopic(ctx, "mem://mytopic") if err != nil { log.Fatal(err) } defer topic.Shutdown(ctx) // Similarly, we can open a subscription using a URL. // Prefixes "pubsub+" or "pubsub+subscription+" work as well. sub, err := pubsub.OpenSubscription(ctx, "mem://mytopic") if err != nil { log.Fatal(err) } defer sub.Shutdown(ctx) // Now we can use topic to send messages. if err := topic.Send(ctx, &pubsub.Message{Body: []byte("Hello, world!")}); err != nil { log.Fatal(err) } // And receive it from sub. m, err := sub.Receive(ctx) if err != nil { log.Fatal(err) } fmt.Printf("%s\n", m.Body) m.Ack() }
Output: Hello, world!
func (*Topic) As ¶
As converts i to provider-specific types. See https://godoc.org/gocloud.dev#hdr-As for background information, the "As" examples in this package for examples, and the provider-specific package documentation for the specific types supported for that provider.
Example ¶
package main import ( "context" "log" "gocloud.dev/pubsub" pbraw "cloud.google.com/go/pubsub/apiv1" ) func main() { // This example is specific to the gcppubsub implementation; it demonstrates // access to the underlying PublisherClient type. // The types exposed for As by gcppubsub are documented in // https://godoc.org/gocloud.dev/pubsub/gcppubsub#hdr-As ctx := context.Background() topic, err := pubsub.OpenTopic(ctx, "gcppubsub://project/topic") if err != nil { log.Fatal(err) } defer topic.Shutdown(ctx) var pc *pbraw.PublisherClient if topic.As(&pc) { _ = pc } }
Output:
func (*Topic) ErrorAs ¶ added in v0.10.0
ErrorAs converts err to provider-specific types. ErrorAs panics if i is nil or not a pointer. ErrorAs returns false if err == nil. See https://godoc.org/gocloud.dev#hdr-As for background information.
Example ¶
package main import ( "context" "log" "gocloud.dev/pubsub" "google.golang.org/grpc/status" ) func main() { // This example is specific to the gcppubsub implementation; it demonstrates // access to the underlying Status type. // The types exposed for As by gcppubsub are documented in // https://godoc.org/gocloud.dev/pubsub/gcppubsub#hdr-As ctx := context.Background() topic, err := pubsub.OpenTopic(ctx, "gcppubsub://project/topic") if err != nil { log.Fatal(err) } defer topic.Shutdown(ctx) err = topic.Send(ctx, &pubsub.Message{Body: []byte("hello")}) if err != nil { var s *status.Status if topic.ErrorAs(err, &s) { _ = s.Code() } log.Fatal(err) } }
Output:
type TopicURLOpener ¶ added in v0.12.0
TopicURLOpener represents types than can open Topics based on a URL. The opener must not modify the URL argument. OpenTopicURL must be safe to call from multiple goroutines.
This interface is generally implemented by types in driver packages.
type URLMux ¶ added in v0.12.0
type URLMux struct {
// contains filtered or unexported fields
}
URLMux is a URL opener multiplexer. It matches the scheme of the URLs against a set of registered schemes and calls the opener that matches the URL's scheme. See https://godoc.org/gocloud.dev#hdr-URLs for more information.
The zero value is a multiplexer with no registered schemes.
func DefaultURLMux ¶ added in v0.12.0
func DefaultURLMux() *URLMux
DefaultURLMux returns the URLMux used by OpenTopic and OpenSubscription.
Driver packages can use this to register their TopicURLOpener and/or SubscriptionURLOpener on the mux.
func (*URLMux) OpenSubscription ¶ added in v0.12.0
OpenSubscription calls OpenSubscriptionURL with the URL parsed from urlstr. OpenSubscription is safe to call from multiple goroutines.
func (*URLMux) OpenSubscriptionURL ¶ added in v0.12.0
OpenSubscriptionURL dispatches the URL to the opener that is registered with the URL's scheme. OpenSubscriptionURL is safe to call from multiple goroutines.
func (*URLMux) OpenTopic ¶ added in v0.12.0
OpenTopic calls OpenTopicURL with the URL parsed from urlstr. OpenTopic is safe to call from multiple goroutines.
func (*URLMux) OpenTopicURL ¶ added in v0.12.0
OpenTopicURL dispatches the URL to the opener that is registered with the URL's scheme. OpenTopicURL is safe to call from multiple goroutines.
func (*URLMux) RegisterSubscription ¶ added in v0.12.0
func (mux *URLMux) RegisterSubscription(scheme string, opener SubscriptionURLOpener)
RegisterSubscription registers the opener with the given scheme. If an opener already exists for the scheme, RegisterSubscription panics.
func (*URLMux) RegisterTopic ¶ added in v0.12.0
func (mux *URLMux) RegisterTopic(scheme string, opener TopicURLOpener)
RegisterTopic registers the opener with the given scheme. If an opener already exists for the scheme, RegisterTopic panics.
func (*URLMux) SubscriptionSchemes ¶ added in v0.13.0
SubscriptionSchemes returns a sorted slice of the registered Subscription schemes.
func (*URLMux) TopicSchemes ¶ added in v0.13.0
TopicSchemes returns a sorted slice of the registered Topic schemes.
func (*URLMux) ValidSubscriptionScheme ¶ added in v0.13.0
ValidSubscriptionScheme returns true iff scheme has been registered for Subscriptions.
func (*URLMux) ValidTopicScheme ¶ added in v0.13.0
ValidTopicScheme returns true iff scheme has been registered for Topics.
Directories
¶
Path | Synopsis |
---|---|
Package awssnssqs provides an implementation of pubsub that uses AWS SNS (Simple Notification Service) and SQS (Simple Queueing Service).
|
Package awssnssqs provides an implementation of pubsub that uses AWS SNS (Simple Notification Service) and SQS (Simple Queueing Service). |
Package azuresb provides an implementation of pubsub using Azure Service Bus Topic and Subscription.
|
Package azuresb provides an implementation of pubsub using Azure Service Bus Topic and Subscription. |
Package driver defines a set of interfaces that the pubsub package uses to interact with the underlying pubsub services.
|
Package driver defines a set of interfaces that the pubsub package uses to interact with the underlying pubsub services. |
Package drivertest provides a conformance test for implementations of driver.
|
Package drivertest provides a conformance test for implementations of driver. |
Package gcppubsub provides a pubsub implementation that uses GCP PubSub.
|
Package gcppubsub provides a pubsub implementation that uses GCP PubSub. |
kafkapubsub
module
|
|
Package mempubsub provides an in-memory pubsub implementation.
|
Package mempubsub provides an in-memory pubsub implementation. |
Package natspubsub provides a pubsub implementation for NATS.io.
|
Package natspubsub provides a pubsub implementation for NATS.io. |
Package rabbitpubsub provides an pubsub implementation for RabbitMQ.
|
Package rabbitpubsub provides an pubsub implementation for RabbitMQ. |