Interface PubsubOptions
- All Superinterfaces:
ApplicationNameOptions
,GcpOptions
,GoogleApiDebugOptions
,HasDisplayData
,PipelineOptions
,StreamingOptions
- All Known Subinterfaces:
DataflowPipelineOptions
,DataflowWorkerHarnessOptions
,TestDataflowPipelineOptions
,TestPubsubOptions
public interface PubsubOptions
extends ApplicationNameOptions, GcpOptions, PipelineOptions, 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
GcpOptions.DefaultProjectFactory, GcpOptions.EnableStreamingEngineFactory, GcpOptions.GcpOAuthScopesFactory, GcpOptions.GcpTempLocationFactory, GcpOptions.GcpUserCredentialsFactory
Nested classes/interfaces inherited from interface org.apache.beam.sdk.extensions.gcp.options.GoogleApiDebugOptions
GoogleApiDebugOptions.GoogleApiTracer
Nested classes/interfaces inherited from interface org.apache.beam.sdk.options.PipelineOptions
PipelineOptions.AtomicLongFactory, PipelineOptions.CheckEnabled, PipelineOptions.DirectRunner, PipelineOptions.JobNameFactory, PipelineOptions.UserAgentFactory
-
Field Summary
Fields inherited from interface org.apache.beam.sdk.extensions.gcp.options.GcpOptions
STREAMING_ENGINE_EXPERIMENT, WINDMILL_SERVICE_EXPERIMENT
-
Method Summary
Modifier and TypeMethodDescriptionRoot URL for use with the Google Cloud Pub/Sub API.void
setPubsubRootUrl
(String value) static String
targetForRootUrl
(String urlString) Internal only utility for convertinggetPubsubRootUrl()
(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, revision, setJobName, setOptionsId, setRunner, setStableUniqueNames, setTempLocation, setUserAgent
Methods inherited from interface org.apache.beam.sdk.options.StreamingOptions
getUpdateCompatibilityVersion, isStreaming, setStreaming, setUpdateCompatibilityVersion
-
Method Details
-
targetForRootUrl
Internal only utility for convertinggetPubsubRootUrl()
(e.g.https://<host>
) to an endpoint target, usable by GCP client libraries (e.g.<host>:443
) -
getPubsubRootUrl
Root URL for use with the Google Cloud Pub/Sub API. -
setPubsubRootUrl
-