Class PubsubSchemaTransformReadProvider

  • All Implemented Interfaces:
    org.apache.beam.sdk.schemas.transforms.SchemaTransformProvider

    @Internal
    @Experimental(SCHEMAS)
    public class PubsubSchemaTransformReadProvider
    extends org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider<PubsubSchemaTransformReadConfiguration>
    An implementation of TypedSchemaTransformProvider for Pub/Sub reads configured using PubsubSchemaTransformReadConfiguration.

    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.

    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      protected java.lang.Class<PubsubSchemaTransformReadConfiguration> configurationClass()
      Returns the expected class of the configuration.
      protected org.apache.beam.sdk.schemas.transforms.SchemaTransform from​(PubsubSchemaTransformReadConfiguration configuration)
      Returns the expected SchemaTransform of the configuration.
      java.lang.String identifier()
      Implementation of the TypedSchemaTransformProvider identifier method.
      java.util.List<java.lang.String> inputCollectionNames()
      Implementation of the TypedSchemaTransformProvider inputCollectionNames method.
      java.util.List<java.lang.String> outputCollectionNames()
      Implementation of the TypedSchemaTransformProvider outputCollectionNames method.
      • Methods inherited from class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider

        configurationSchema, dependencies, from
      • Methods inherited from class java.lang.Object

        clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
    • Constructor Detail

      • PubsubSchemaTransformReadProvider

        public PubsubSchemaTransformReadProvider()
    • Method Detail

      • identifier

        public java.lang.String identifier()
        Implementation of the TypedSchemaTransformProvider identifier method.
      • inputCollectionNames

        public java.util.List<java.lang.String> inputCollectionNames()
        Implementation of the TypedSchemaTransformProvider inputCollectionNames method. Since no input is expected, this returns an empty list.
      • outputCollectionNames

        public java.util.List<java.lang.String> outputCollectionNames()
        Implementation of the TypedSchemaTransformProvider outputCollectionNames method. Since a single output is expected, this returns a list with a single name.