Package org.apache.beam.runners.spark
Class SparkRunnerDebugger.DebugSparkPipelineResult
java.lang.Object
org.apache.beam.runners.spark.SparkPipelineResult
org.apache.beam.runners.spark.SparkRunnerDebugger.DebugSparkPipelineResult
- All Implemented Interfaces:
 PipelineResult
- Enclosing class:
 SparkRunnerDebugger
PipelineResult of running a 
Pipeline using SparkRunnerDebugger Use getDebugString() to get a String representation of the Pipeline translated into
 Spark native operations.- 
Nested Class Summary
Nested classes/interfaces inherited from interface org.apache.beam.sdk.PipelineResult
PipelineResult.State - 
Method Summary
Modifier and TypeMethodDescriptionprotected PipelineResult.StateawaitTermination(Duration duration) protected voidstop()Methods inherited from class org.apache.beam.runners.spark.SparkPipelineResult
cancel, getState, metrics, waitUntilFinish, waitUntilFinish 
- 
Method Details
- 
stop
protected void stop()- Specified by:
 stopin classSparkPipelineResult
 - 
awaitTermination
protected PipelineResult.State awaitTermination(Duration duration) throws TimeoutException, ExecutionException, InterruptedException - Specified by:
 awaitTerminationin classSparkPipelineResult- Throws:
 TimeoutExceptionExecutionExceptionInterruptedException
 
 -