Class PubsubWriteSchemaTransformConfiguration
java.lang.Object
org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformConfiguration
@DefaultSchema(AutoValueSchema.class)
public abstract class PubsubWriteSchemaTransformConfiguration
extends Object
Configuration for writing to Pub/Sub.
Internal only: This class is actively being worked on, and it will likely change. We provide no backwards compatibility guarantees, and it should not be implemented outside the Beam repository.
-
Constructor Details
-
PubsubWriteSchemaTransformConfiguration
public PubsubWriteSchemaTransformConfiguration()
-
-
Method Details
-
getFormat
@SchemaFieldDescription("The encoding format for the data stored in Pubsub. Valid options are: RAW,AVRO,JSON") public abstract String getFormat() -
getTopic
@SchemaFieldDescription("The name of the topic to write data to. Format: projects/${PROJECT}/topics/${TOPIC}") public abstract String getTopic() -
getAttributes
@SchemaFieldDescription("The set of fields to write as PubSub attributes instead of part of the payload.") @Nullable public abstract List<String> getAttributes() -
getAttributesMap
@SchemaFieldDescription("A map field to write as PubSub attributes instead of part of the payload.") @Nullable public abstract String getAttributesMap() -
getIdAttribute
@SchemaFieldDescription("If set, will set an attribute for each Cloud Pub/Sub message with the given name and a unique value. This attribute can then be used in a ReadFromPubSub PTransform to deduplicate messages.") @Nullable public abstract String getIdAttribute() -
getTimestampAttribute
@SchemaFieldDescription("If set, will set an attribute for each Cloud Pub/Sub message with the given name and the message\'s publish time as the value.") @Nullable public abstract String getTimestampAttribute() -
getErrorHandling
@SchemaFieldDescription("Specifies how to handle errors.") @Nullable public abstract PubsubWriteSchemaTransformConfiguration.ErrorHandling getErrorHandling() -
builder
-