Class PublisherOptions

java.lang.Object
org.apache.beam.sdk.io.gcp.pubsublite.PublisherOptions
All Implemented Interfaces:
Serializable

public abstract class PublisherOptions extends Object implements Serializable
Options needed for a Pub/Sub Lite Publisher.
See Also:
  • Constructor Details

    • PublisherOptions

      public PublisherOptions()
  • Method Details

    • topicPath

      public abstract com.google.cloud.pubsublite.TopicPath topicPath()
    • newBuilder

      public static PublisherOptions.Builder newBuilder()