See: Description
Interface | Description |
---|---|
PubsubOptions |
Properties that can be set when using Google Cloud Pub/Sub with the Apache Beam SDK.
|
Class | Description |
---|---|
PubsubCoderProviderRegistrar |
A
CoderProviderRegistrar for standard types used with PubsubIO . |
PubsubIO |
Read and Write
PTransform s for Cloud Pub/Sub streams. |
PubsubIO.PubsubSubscription |
Class representing a Cloud Pub/Sub Subscription.
|
PubsubIO.PubsubTopic |
Class representing a Cloud Pub/Sub Topic.
|
PubsubIO.Read<T> |
Implementation of
PubsubIO.read() . |
PubsubIO.Write<T> |
Implementation of
PubsubIO.write() . |
PubsubMessage |
Class representing a Pub/Sub message.
|
PubsubMessagePayloadOnlyCoder |
A coder for PubsubMessage treating the raw bytes being decoded as the message's payload.
|
PubsubMessageWithAttributesCoder |
A coder for PubsubMessage including attributes.
|
PubsubUnboundedSink |
A PTransform which streams messages to Pubsub.
|
PubsubUnboundedSource |
Users should use
PubsubIO.read() instead. |
PubsubIO