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 class
A 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.UserAgentFactory
Nested classes/interfaces inherited from interface org.apache.beam.runners.spark.SparkCommonPipelineOptions
SparkCommonPipelineOptions.StorageLevelFactory, SparkCommonPipelineOptions.TmpCheckpointDirFactory
Nested 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 TypeMethodDescriptionboolean
boolean
void
setDeleteCheckpointDir
(boolean deleteCheckpointDir) void
setExpectedAssertions
(Integer expectedAssertions) void
setForceStreaming
(boolean forceStreaming) void
setStopPipelineWatermark
(Long stopPipelineWatermark) Methods inherited from interface org.apache.beam.sdk.options.ApplicationNameOptions
getAppName, setAppName
Methods inherited from interface org.apache.beam.sdk.options.FileStagingOptions
getFilesToStage, setFilesToStage
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.runners.spark.SparkCommonPipelineOptions
getCheckpointDir, getEnableSparkMetricSinks, getPreferGroupByKeyToHandleHugeValues, getSparkMaster, getStorageLevel, setCheckpointDir, setEnableSparkMetricSinks, setPreferGroupByKeyToHandleHugeValues, setSparkMaster, setStorageLevel
Methods inherited from interface org.apache.beam.runners.spark.SparkPipelineOptions
getBatchIntervalMillis, getBundleSize, getCheckpointDurationMillis, getMaxRecordsPerBatch, getMinReadTimeMillis, getReadTimePercentage, getUsesProvidedSparkContext, isCacheDisabled, setBatchIntervalMillis, setBundleSize, setCacheDisabled, setCheckpointDurationMillis, setMaxRecordsPerBatch, setMinReadTimeMillis, setReadTimePercentage, setUsesProvidedSparkContext
Methods inherited from interface org.apache.beam.sdk.options.StreamingOptions
getUpdateCompatibilityVersion, isStreaming, setStreaming, setUpdateCompatibilityVersion
Methods 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)
-