Class PubsubSchemaTransformReadConfiguration


  • @Experimental
    @DefaultSchema(org.apache.beam.sdk.schemas.AutoValueSchema.class)
    public abstract class PubsubSchemaTransformReadConfiguration
    extends java.lang.Object
    Configuration for reading from 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 Detail

      • PubsubSchemaTransformReadConfiguration

        public PubsubSchemaTransformReadConfiguration()
    • Method Detail

      • getDataSchema

        public abstract org.apache.beam.sdk.schemas.Schema getDataSchema()
        The expected schema of the Pub/Sub message.
      • getDeadLetterQueue

        @Nullable
        public abstract java.lang.String getDeadLetterQueue()
        The Pub/Sub topic path to write failures.

        See PubsubIO.PubsubTopic.fromPath(String) for more details on the format of the dead letter queue topic string.

      • getFormat

        @Nullable
        public abstract java.lang.String getFormat()
        The expected format of the Pub/Sub message.

        Used to retrieve the PayloadSerializer from PayloadSerializers.

      • getProtoClass

        @Nullable
        public abstract java.lang.String getProtoClass()
        Used by the ProtoPayloadSerializerProvider when serializing from a Pub/Sub message.
      • getSubscription

        @Nullable
        public abstract java.lang.String getSubscription()
        The subscription from which to read Pub/Sub messages.

        See PubsubIO.PubsubSubscription.fromPath(String) for more details on the format of the subscription string.

      • getThriftClass

        @Nullable
        public abstract java.lang.String getThriftClass()
        Used by the ThriftPayloadSerializerProvider when serializing from a Pub/Sub message.
      • getThriftProtocolFactoryClass

        @Nullable
        public abstract java.lang.String getThriftProtocolFactoryClass()
        Used by the ThriftPayloadSerializerProvider when serializing from a Pub/Sub message.
      • getTimestampAttribute

        @Nullable
        public abstract java.lang.String getTimestampAttribute()
        When reading from Cloud Pub/Sub where record timestamps are provided as Pub/Sub message attributes, specifies the name of the attribute that contains the timestamp.
      • getIdAttribute

        @Nullable
        public abstract java.lang.String getIdAttribute()
        When reading from Cloud Pub/Sub where unique record identifiers are provided as Pub/Sub message attributes, specifies the name of the attribute containing the unique identifier.
      • getTopic

        @Nullable
        public abstract java.lang.String getTopic()
        The topic from which to read Pub/Sub messages.

        See PubsubIO.PubsubTopic.fromPath(String) for more details on the format of the topic string.