Package org.apache.beam.sdk.io.gcp.pubsub
package org.apache.beam.sdk.io.gcp.pubsub
Defines transforms for reading and writing from Google
Cloud Pub/Sub.
- See Also:
-
ClassDescriptionExposes
PubsubIO.Read
as an external transform for cross-language usage.Parameters class to expose the transform to an external SDK.ExposesPubsubIO.Write
as an external transform for cross-language usage.Parameters class to expose the transform to an external SDK.PreparePubsubWriteDoFn<InputT>An (abstract) helper class for talking to Pubsub via an underlying transport.A message received from Pubsub.A message to be sent to Pubsub.Path representing a cloud project id.Factory for creating clients.Path representing a Pubsub schema.Path representing a Pubsub subscription.Path representing a Pubsub topic.ACoderProviderRegistrar
for standard types used withPubsubIO
.A helper class for talking to Pubsub via grpc.Read and WritePTransform
s for Cloud Pub/Sub streams.Class representing a Cloud Pub/Sub Subscription.Class representing a Cloud Pub/Sub Topic.Implementation of read methods.Implementation of write methods.A Pubsub client using JSON transport.Class representing a Pub/Sub message.A coder for PubsubMessage treating the raw bytes being decoded as the message's payload.Common util functions for converting between PubsubMessage proto andPubsubMessage
.Provides aSchemaCoder
forPubsubMessage
, including the topic and all fields of a PubSub message from server.A coder for PubsubMessage including all fields of a PubSub message from server.A coder for PubsubMessage including attributes and the message id from the PubSub server.A coder for PubsubMessage including attributes.A coder for PubsubMessage treating the raw bytes being decoded as the message's payload, with the message id from the PubSub server.A coder for PubsubMessage including the topic from the PubSub server.Properties that can be set when using Google Cloud Pub/Sub with the Apache Beam SDK.Configuration for reading from Pub/Sub.An implementation ofTypedSchemaTransformProvider
for Pub/Sub reads configured usingPubsubReadSchemaTransformConfiguration
.An implementation ofSchemaIOProvider
for reading and writing JSON/AVRO payloads withPubsubIO
.A (partial) implementation ofPubsubClient
for use by unit tests.Closing the factory will validate all expected messages were processed.A PTransform which streams messages to Pubsub.Users should useinvalid reference
PubsubIO#read
Configuration for writing to Pub/Sub.An implementation ofTypedSchemaTransformProvider
for Pub/Sub reads configured usingPubsubWriteSchemaTransformConfiguration
.Test rule which creates a new topic and subscription with randomized names and exposes the APIs to work with them.Test rule which observes elements of thePCollection
and checks whether they match the success criteria.