@DefaultSchema(value=AutoValueSchema.class) public abstract class PubsubWriteSchemaTransformConfiguration extends java.lang.Object
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.
Modifier and Type | Class and Description |
---|---|
static class |
PubsubWriteSchemaTransformConfiguration.Builder |
static class |
PubsubWriteSchemaTransformConfiguration.ErrorHandling |
Constructor and Description |
---|
PubsubWriteSchemaTransformConfiguration() |
Modifier and Type | Method and Description |
---|---|
static PubsubWriteSchemaTransformConfiguration.Builder |
builder() |
abstract java.util.List<java.lang.String> |
getAttributes() |
abstract java.lang.String |
getAttributesMap() |
abstract PubsubWriteSchemaTransformConfiguration.ErrorHandling |
getErrorHandling() |
abstract java.lang.String |
getFormat() |
abstract java.lang.String |
getIdAttribute() |
abstract java.lang.String |
getTimestampAttribute() |
abstract java.lang.String |
getTopic() |
public PubsubWriteSchemaTransformConfiguration()
@SchemaFieldDescription(value="The encoding format for the data stored in Pubsub. Valid options are: RAW,AVRO,JSON") public abstract java.lang.String getFormat()
@SchemaFieldDescription(value="The name of the topic to write data to. Format: projects/${PROJECT}/topics/${TOPIC}") public abstract java.lang.String getTopic()
@SchemaFieldDescription(value="The set of fields to write as PubSub attributes instead of part of the payload.") @Nullable public abstract java.util.List<java.lang.String> getAttributes()
@SchemaFieldDescription(value="A map field to write as PubSub attributes instead of part of the payload.") @Nullable public abstract java.lang.String getAttributesMap()
@SchemaFieldDescription(value="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 java.lang.String getIdAttribute()
@SchemaFieldDescription(value="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 java.lang.String getTimestampAttribute()
@SchemaFieldDescription(value="Specifies how to handle errors.") @Nullable public abstract PubsubWriteSchemaTransformConfiguration.ErrorHandling getErrorHandling()
public static PubsubWriteSchemaTransformConfiguration.Builder builder()