Documentation ¶
Overview ¶
Package pubsubio provides access to PubSub on Dataflow streaming. Experimental.
Index ¶
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func Read ¶
func Read(s beam.Scope, project, topic string, opts *ReadOptions) beam.PCollection
Read reads an unbounded number of PubSubMessages from the given pubsub topic. It produces an unbounded PCollecton<*PubSubMessage>, if WithAttributes is set, or an unbounded PCollection<[]byte>.
Types ¶
Click to show internal directories.
Click to hide internal directories.