Class PipelineExecution

Object
org.apache.spark.sql.pipelines.graph.PipelineExecution

public class PipelineExecution extends Object
Executes a DataflowGraph by resolving the graph, materializing datasets, and running the flows.

param: context The context for this pipeline update.

  • Constructor Details

  • Method Details

    • executionStarted

      public boolean executionStarted()
    • runPipeline

      public void runPipeline()
      Starts pipeline execution and waits for it to complete before returning.
    • startPipeline

      public 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.
    • stopPipeline

      public void stopPipeline()
      Stops the pipeline execution by stopping the graph execution thread.