Package org.apache.beam.runners.spark
Interface TestSparkPipelineOptions
- All Superinterfaces:
ApplicationNameOptions,FileStagingOptions,HasDisplayData,PipelineOptions,SparkCommonPipelineOptions,SparkPipelineOptions,StreamingOptions,TestPipelineOptions
A
SparkPipelineOptions for tests.-
Nested Class Summary
Nested ClassesModifier and TypeInterfaceDescriptionstatic classA factory to provide the default watermark to stop a pipeline that reads from an unbounded source.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.TmpCheckpointDirFactoryNested classes/interfaces inherited from interface org.apache.beam.sdk.testing.TestPipelineOptions
TestPipelineOptions.AlwaysPassMatcher, TestPipelineOptions.AlwaysPassMatcherFactory -
Field Summary
Fields inherited from interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
DEFAULT_MASTER_URL -
Method Summary
Modifier and TypeMethodDescriptionbooleanbooleanvoidsetDeleteCheckpointDir(boolean deleteCheckpointDir) voidsetExpectedAssertions(Integer expectedAssertions) voidsetForceStreaming(boolean forceStreaming) voidsetStopPipelineWatermark(Long stopPipelineWatermark) 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, getGbek, getJobName, getOptionsId, getRunner, getStableUniqueNames, getTempLocation, getUserAgent, outputRuntimeOptions, revision, setGbek, setJobName, setOptionsId, setRunner, setStableUniqueNames, setTempLocation, setUserAgentMethods 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, setUpdateCompatibilityVersionMethods inherited from interface org.apache.beam.sdk.testing.TestPipelineOptions
getOnCreateMatcher, getOnSuccessMatcher, getTempRoot, getTestTimeoutSeconds, isBlockOnRun, setBlockOnRun, setOnCreateMatcher, setOnSuccessMatcher, setTempRoot, setTestTimeoutSeconds
-
Method Details
-
isForceStreaming
-
setForceStreaming
void setForceStreaming(boolean forceStreaming) -
getExpectedAssertions
-
setExpectedAssertions
-
getStopPipelineWatermark
-
setStopPipelineWatermark
-
isDeleteCheckpointDir
-
setDeleteCheckpointDir
void setDeleteCheckpointDir(boolean deleteCheckpointDir)
-