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.
|
PubsubTestClient.PubsubTestClientFactory |
Closing the factory will validate all expected messages were processed.
|
TestPubsub.PollingAssertion | |
TestPubsubOptions |
Class | Description |
---|---|
ExternalRead |
Exposes
PubsubIO.Read as an external transform for cross-language usage. |
ExternalRead.Configuration |
Parameters class to expose the transform to an external SDK.
|
ExternalRead.ReadBuilder | |
ExternalWrite |
Exposes
PubsubIO.Write as an external transform for cross-language usage. |
ExternalWrite.Configuration |
Parameters class to expose the transform to an external SDK.
|
ExternalWrite.ParsePubsubMessageProtoAsPayloadFromWindowedValue | |
ExternalWrite.WriteBuilder | |
PreparePubsubWriteDoFn<InputT> | |
PubsubClient |
An (abstract) helper class for talking to Pubsub via an underlying transport.
|
PubsubClient.IncomingMessage |
A message received from Pubsub.
|
PubsubClient.OutgoingMessage |
A message to be sent to Pubsub.
|
PubsubClient.ProjectPath |
Path representing a cloud project id.
|
PubsubClient.SchemaPath |
Path representing a Pubsub schema.
|
PubsubClient.SubscriptionPath |
Path representing a Pubsub subscription.
|
PubsubClient.TopicPath |
Path representing a Pubsub topic.
|
PubsubCoderProviderRegistrar |
A
CoderProviderRegistrar for standard types used with PubsubIO . |
PubsubDlqProvider | |
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 read methods.
|
PubsubIO.Write<T> |
Implementation of write methods.
|
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.
|
PubsubMessages |
Common util functions for converting between PubsubMessage proto and
PubsubMessage . |
PubsubMessages.DeserializeBytesIntoPubsubMessagePayloadOnly | |
PubsubMessages.ParsePayloadAsPubsubMessageProto | |
PubsubMessages.ParsePubsubMessageProtoAsPayload | |
PubsubMessageWithAttributesAndMessageIdAndOrderingKeyCoder |
A coder for PubsubMessage including all fields of a PubSub message from server.
|
PubsubMessageWithAttributesAndMessageIdCoder |
A coder for PubsubMessage including attributes and the message id from the PubSub server.
|
PubsubMessageWithAttributesCoder |
A coder for PubsubMessage including attributes.
|
PubsubMessageWithMessageIdCoder |
A coder for PubsubMessage treating the raw bytes being decoded as the message's payload, with the
message id from the PubSub server.
|
PubsubMessageWithTopicCoder |
A coder for PubsubMessage including the topic from the PubSub server.
|
PubSubPayloadTranslation | |
PubSubPayloadTranslation.ReadRegistrar | |
PubSubPayloadTranslation.WriteRegistrar | |
PubsubReadSchemaTransformConfiguration |
Configuration for reading from Pub/Sub.
|
PubsubReadSchemaTransformConfiguration.Builder | |
PubsubReadSchemaTransformProvider |
An implementation of
TypedSchemaTransformProvider for Pub/Sub reads configured using
PubsubReadSchemaTransformConfiguration . |
PubsubSchemaIOProvider |
An implementation of
SchemaIOProvider for reading and writing JSON/AVRO payloads with
PubsubIO . |
PubsubTestClient |
A (partial) implementation of
PubsubClient for use by unit tests. |
PubsubUnboundedSink |
A PTransform which streams messages to Pubsub.
|
PubsubUnboundedSource |
Users should use
PubsubIO#read instead. |
PubsubWriteSchemaTransformConfiguration |
Configuration for writing to Pub/Sub.
|
PubsubWriteSchemaTransformConfiguration.Builder |
Builder for
PubsubWriteSchemaTransformConfiguration . |
PubsubWriteSchemaTransformConfiguration.SourceConfiguration | |
PubsubWriteSchemaTransformConfiguration.SourceConfiguration.Builder | |
PubsubWriteSchemaTransformConfiguration.TargetConfiguration | |
PubsubWriteSchemaTransformConfiguration.TargetConfiguration.Builder | |
PubsubWriteSchemaTransformProvider |
An implementation of
TypedSchemaTransformProvider for Pub/Sub reads configured using
PubsubWriteSchemaTransformConfiguration . |
TestPubsub |
Test rule which creates a new topic and subscription with randomized names and exposes the APIs
to work with them.
|
TestPubsubSignal |
Test rule which observes elements of the
PCollection and checks whether they match the
success criteria. |
PubsubIO