See: Description
Interface | Description |
---|---|
PubsubClient.PubsubClientFactory |
Factory for creating clients.
|
PubsubOptions |
Properties that can be set when using Google Cloud Pub/Sub with the Apache Beam SDK.
|
TestPubsubOptions |
Class | Description |
---|---|
PubsubClient |
An (abstract) helper class for talking to Pubsub via an underlying transport.
|
PubsubClient.OutgoingMessage |
A message to be sent to Pubsub.
|
PubsubClient.ProjectPath |
Path representing a cloud project id.
|
PubsubClient.SubscriptionPath |
Path representing a Pubsub subscription.
|
PubsubClient.TopicPath |
Path representing a Pubsub topic.
|
PubsubCoderProviderRegistrar |
A
CoderProviderRegistrar for standard types used with PubsubIO . |
PubsubGrpcClient |
A helper class for talking to Pubsub via grpc.
|
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() . |
PubsubJsonClient |
A Pubsub client using JSON transport.
|
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. |
TestPubsub |
Test rule which creates a new topic with randomized name and exposes the APIs to work with it.
|
TestPubsubSignal |
Test rule which observes elements of the
PCollection and checks whether they match the
success criteria. |
PubsubIO