Class TriggeredGraphExecution
Object
org.apache.spark.sql.pipelines.graph.GraphExecution
org.apache.spark.sql.pipelines.graph.TriggeredGraphExecution
- All Implemented Interfaces:
- org.apache.spark.internal.Logging
Executes all of the flows in the given graph in topological order. Each flow processes
 all available data before downstream flows are triggered.
 
param: graphForExecution the graph to execute. param: env the context in which the graph is executed. param: onCompletion a callback to execute after all streams are done. The boolean argument is true if the execution was successful. param: clock a clock used to determine the time of execution.
- 
Nested Class SummaryNested ClassesModifier and TypeClassDescriptionstatic interfacestatic classNested classes/interfaces inherited from class org.apache.spark.sql.pipelines.graph.GraphExecutionGraphExecution.FlowExecutionAction, GraphExecution.FlowExecutionStopReason, GraphExecution.RetryFlowExecution$, GraphExecution.StopFlowExecution, GraphExecution.StopFlowExecution$Nested classes/interfaces inherited from interface org.apache.spark.internal.Loggingorg.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
- 
Constructor SummaryConstructorsConstructorDescriptionTriggeredGraphExecution(DataflowGraph graphForExecution, PipelineUpdateContext env, scala.Function1<RunTerminationReason, scala.runtime.BoxedUnit> onCompletion, Clock clock) 
- 
Method SummaryModifier and TypeMethodDescriptionvoidBlocks the current thread while any flows are queued or running.Returns the reason why this flow execution has terminated.voidstart()Starts the execution of flows ingraphForExecution.voidstop()Stops this execution by stopping all streams and terminating any other resources.streamTrigger(Flow flow) The `Trigger` configuration for a streaming flow.Methods inherited from class org.apache.spark.sql.pipelines.graph.GraphExecutiondetermineFlowExecutionActionFromError, flowExecutions, graphForExecution, LogStringContext, maxRetryAttemptsForFlow, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq, planAndStartFlow, stopFlow, stopThreadMethods inherited from class java.lang.Objectequals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.spark.internal.LogginginitializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, isTraceEnabled, log, logBasedOnLevel, logDebug, logDebug, logDebug, logDebug, logError, logError, logError, logError, logInfo, logInfo, logInfo, logInfo, logName, LogStringContext, logTrace, logTrace, logTrace, logTrace, logWarning, logWarning, logWarning, logWarning, MDC, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq, withLogContext
- 
Constructor Details- 
TriggeredGraphExecutionpublic TriggeredGraphExecution(DataflowGraph graphForExecution, PipelineUpdateContext env, scala.Function1<RunTerminationReason, scala.runtime.BoxedUnit> onCompletion, Clock clock) 
 
- 
- 
Method Details- 
streamTriggerDescription copied from class:GraphExecutionThe `Trigger` configuration for a streaming flow.- Specified by:
- streamTriggerin class- GraphExecution
 
- 
startpublic void start()Description copied from class:GraphExecutionStarts the execution of flows ingraphForExecution. Does not block.- Overrides:
- startin class- GraphExecution
 
- 
awaitCompletionpublic void awaitCompletion()Description copied from class:GraphExecutionBlocks the current thread while any flows are queued or running. Returns when all flows that could be run have completed. When this returns, all flows are either SUCCESSFUL, TERMINATED_WITH_ERROR, SKIPPED, CANCELED, or EXCLUDED.- Specified by:
- awaitCompletionin class- GraphExecution
 
- 
stoppublic void stop()Description copied from class:GraphExecutionStops this execution by stopping all streams and terminating any other resources.This method may be called multiple times due to race conditions and must be idempotent. - Overrides:
- stopin class- GraphExecution
 
- 
getRunTerminationReasonDescription copied from class:GraphExecutionReturns the reason why this flow execution has terminated. If the function is called before the flow has not terminated yet, the behavior is undefined, and may returnUnexpectedRunFailure.- Specified by:
- getRunTerminationReasonin class- GraphExecution
- Returns:
- (undocumented)
 
 
-