Class PipelineExecution
Object
org.apache.spark.sql.pipelines.graph.PipelineExecution
Executes a 
DataflowGraph by resolving the graph, materializing datasets, and running the
 flows.
 param: context The context for this pipeline update.
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionvoidValidates that the pipeline graph can be successfully resolved and validates it.booleanvoidStarts pipeline execution and waits for it to complete before returning.voidStarts the pipeline execution by initializing the graph and starting the graph execution thread.voidStops the pipeline execution by stopping the graph execution thread.
- 
Constructor Details- 
PipelineExecution
 
- 
- 
Method Details- 
dryRunPipelinepublic void dryRunPipeline()Validates that the pipeline graph can be successfully resolved and validates it.
- 
executionStartedpublic boolean executionStarted()
- 
runPipelinepublic void runPipeline()Starts pipeline execution and waits for it to complete before returning.
- 
startPipelinepublic void startPipeline()Starts the pipeline execution by initializing the graph and starting the graph execution thread. This function does not block on the completion of the graph execution thread.
- 
stopPipelinepublic void stopPipeline()Stops the pipeline execution by stopping the graph execution thread.
 
-