Interface PubsubOptions

  • All Superinterfaces:
    org.apache.beam.sdk.options.ApplicationNameOptions, org.apache.beam.sdk.extensions.gcp.options.GcpOptions, org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions, org.apache.beam.sdk.transforms.display.HasDisplayData, org.apache.beam.sdk.options.PipelineOptions, org.apache.beam.sdk.options.StreamingOptions
    All Known Subinterfaces:
    TestPubsubOptions

    public interface PubsubOptions
    extends org.apache.beam.sdk.options.ApplicationNameOptions, org.apache.beam.sdk.extensions.gcp.options.GcpOptions, org.apache.beam.sdk.options.PipelineOptions, org.apache.beam.sdk.options.StreamingOptions
    Properties that can be set when using Google Cloud Pub/Sub with the Apache Beam SDK.
    • Nested Class Summary

      • Nested classes/interfaces inherited from interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions

        org.apache.beam.sdk.extensions.gcp.options.GcpOptions.DefaultProjectFactory, org.apache.beam.sdk.extensions.gcp.options.GcpOptions.EnableStreamingEngineFactory, org.apache.beam.sdk.extensions.gcp.options.GcpOptions.GcpOAuthScopesFactory, org.apache.beam.sdk.extensions.gcp.options.GcpOptions.GcpTempLocationFactory, org.apache.beam.sdk.extensions.gcp.options.GcpOptions.GcpUserCredentialsFactory
      • Nested classes/interfaces inherited from interface org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions

        org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions.GoogleApiTracer
      • Nested classes/interfaces inherited from interface org.apache.beam.sdk.options.PipelineOptions

        org.apache.beam.sdk.options.PipelineOptions.AtomicLongFactory, org.apache.beam.sdk.options.PipelineOptions.CheckEnabled, org.apache.beam.sdk.options.PipelineOptions.DirectRunner, org.apache.beam.sdk.options.PipelineOptions.JobNameFactory, org.apache.beam.sdk.options.PipelineOptions.UserAgentFactory
    • Field Summary

      • Fields inherited from interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions

        STREAMING_ENGINE_EXPERIMENT, WINDMILL_SERVICE_EXPERIMENT
    • Method Summary

      All Methods Static Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      java.lang.String getPubsubRootUrl()
      Root URL for use with the Google Cloud Pub/Sub API.
      void setPubsubRootUrl​(java.lang.String value)  
      static java.lang.String targetForRootUrl​(java.lang.String urlString)
      Internal only utility for converting getPubsubRootUrl() (e.g.
      • Methods inherited from interface org.apache.beam.sdk.options.ApplicationNameOptions

        getAppName, setAppName
      • Methods inherited from interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions

        getCredentialFactoryClass, getDataflowKmsKey, getGcpCredential, getGcpOauthScopes, getGcpTempLocation, getImpersonateServiceAccount, getProject, getWorkerRegion, getWorkerZone, getZone, isEnableStreamingEngine, setCredentialFactoryClass, setDataflowKmsKey, setEnableStreamingEngine, setGcpCredential, setGcpOauthScopes, setGcpTempLocation, setImpersonateServiceAccount, setProject, setWorkerRegion, setWorkerZone, setZone
      • Methods inherited from interface org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions

        getGoogleApiTrace, setGoogleApiTrace
      • Methods inherited from interface org.apache.beam.sdk.transforms.display.HasDisplayData

        populateDisplayData
      • Methods inherited from interface org.apache.beam.sdk.options.PipelineOptions

        as, getJobName, getOptionsId, getRunner, getStableUniqueNames, getTempLocation, getUserAgent, outputRuntimeOptions, setJobName, setOptionsId, setRunner, setStableUniqueNames, setTempLocation, setUserAgent
      • Methods inherited from interface org.apache.beam.sdk.options.StreamingOptions

        isStreaming, setStreaming
    • Method Detail

      • targetForRootUrl

        @Internal
        static java.lang.String targetForRootUrl​(java.lang.String urlString)
        Internal only utility for converting getPubsubRootUrl() (e.g. https://<host>) to an endpoint target, usable by GCP client libraries (e.g. <host>:443)
      • getPubsubRootUrl

        @String("https://pubsub.googleapis.com")
        @Hidden
        java.lang.String getPubsubRootUrl()
        Root URL for use with the Google Cloud Pub/Sub API.
      • setPubsubRootUrl

        void setPubsubRootUrl​(java.lang.String value)