Package org.apache.beam.runners.spark
Interface SparkPortableStreamingPipelineOptions
- All Superinterfaces:
 ApplicationNameOptions,FileStagingOptions,HasDisplayData,PipelineOptions,PortablePipelineOptions,SparkCommonPipelineOptions,SparkPipelineOptions,StreamingOptions
public interface SparkPortableStreamingPipelineOptions
extends SparkPipelineOptions, PortablePipelineOptions
Pipeline options specific to the Spark portable runner running a streaming job.
- 
Nested Class Summary
Nested classes/interfaces inherited from interface org.apache.beam.sdk.options.PipelineOptions
PipelineOptions.AtomicLongFactory, PipelineOptions.CheckEnabled, PipelineOptions.DirectRunner, PipelineOptions.JobNameFactory, PipelineOptions.UserAgentFactoryNested classes/interfaces inherited from interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
SparkCommonPipelineOptions.StorageLevelFactory, SparkCommonPipelineOptions.TmpCheckpointDirFactory - 
Field Summary
Fields inherited from interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
DEFAULT_MASTER_URL - 
Method Summary
Methods inherited from interface org.apache.beam.sdk.options.ApplicationNameOptions
getAppName, setAppNameMethods inherited from interface org.apache.beam.sdk.options.FileStagingOptions
getFilesToStage, setFilesToStageMethods inherited from interface org.apache.beam.sdk.transforms.display.HasDisplayData
populateDisplayDataMethods inherited from interface org.apache.beam.sdk.options.PipelineOptions
as, getJobName, getOptionsId, getRunner, getStableUniqueNames, getTempLocation, getUserAgent, outputRuntimeOptions, revision, setJobName, setOptionsId, setRunner, setStableUniqueNames, setTempLocation, setUserAgentMethods inherited from interface org.apache.beam.sdk.options.PortablePipelineOptions
getDefaultEnvironmentConfig, getDefaultEnvironmentType, getEnableHeapDumps, getEnvironmentCacheMillis, getEnvironmentExpirationMillis, getEnvironmentOptions, getJobEndpoint, getJobServerTimeout, getLoadBalanceBundles, getOutputExecutablePath, getSdkWorkerParallelism, setDefaultEnvironmentConfig, setDefaultEnvironmentType, setEnableHeapDumps, setEnvironmentCacheMillis, setEnvironmentExpirationMillis, setEnvironmentOptions, setJobEndpoint, setJobServerTimeout, setLoadBalanceBundles, setOutputExecutablePath, setSdkWorkerParallelismMethods inherited from interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
getCheckpointDir, getEnableSparkMetricSinks, getPreferGroupByKeyToHandleHugeValues, getSparkMaster, getStorageLevel, setCheckpointDir, setEnableSparkMetricSinks, setPreferGroupByKeyToHandleHugeValues, setSparkMaster, setStorageLevelMethods inherited from interface org.apache.beam.runners.spark.SparkPipelineOptions
getBatchIntervalMillis, getBundleSize, getCheckpointDurationMillis, getMaxRecordsPerBatch, getMinReadTimeMillis, getReadTimePercentage, getUsesProvidedSparkContext, isCacheDisabled, setBatchIntervalMillis, setBundleSize, setCacheDisabled, setCheckpointDurationMillis, setMaxRecordsPerBatch, setMinReadTimeMillis, setReadTimePercentage, setUsesProvidedSparkContextMethods inherited from interface org.apache.beam.sdk.options.StreamingOptions
getUpdateCompatibilityVersion, isStreaming, setStreaming, setUpdateCompatibilityVersion 
- 
Method Details
- 
getStreamingTimeoutMs
 - 
setStreamingTimeoutMs
 
 -