org.apache.spark.sql.pipelines.graph
TriggeredGraphExecution
Companion object TriggeredGraphExecution
class TriggeredGraphExecution extends GraphExecution
Executes all of the flows in the given graph in topological order. Each flow processes all available data before downstream flows are triggered.
- Alphabetic
- By Inheritance
- TriggeredGraphExecution
- GraphExecution
- Logging
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
- new TriggeredGraphExecution(graphForExecution: DataflowGraph, env: PipelineUpdateContext, onCompletion: (RunTerminationReason) => Unit = _ => (), clock: Clock = new SystemClock())
- graphForExecution
the graph to execute.
- env
the context in which the graph is executed.
- onCompletion
a callback to execute after all streams are done. The boolean argument is true if the execution was successful.
- clock
a clock used to determine the time of execution.
Type Members
- implicit class LogStringContext extends AnyRef
- Definition Classes
- Logging
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def awaitCompletion(): Unit
Blocks the current thread while any flows are queued or running.
Blocks 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.
- Definition Classes
- TriggeredGraphExecution → GraphExecution
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- val flowExecutions: TrieMap[TableIdentifier, FlowExecution]
FlowExecution
s currently being executed and tracked by the graph execution.FlowExecution
s currently being executed and tracked by the graph execution.- Definition Classes
- GraphExecution
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def getRunTerminationReason: RunTerminationReason
Returns the reason why this flow execution has terminated.
Returns 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 return
UnexpectedRunFailure
.- Definition Classes
- TriggeredGraphExecution → GraphExecution
- val graphForExecution: DataflowGraph
- Definition Classes
- GraphExecution
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- def initializeLogIfNecessary(isInterpreter: Boolean): Unit
- Attributes
- protected
- Definition Classes
- Logging
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def isTraceEnabled(): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- def log: Logger
- Attributes
- protected
- Definition Classes
- Logging
- def logBasedOnLevel(level: Level)(f: => MessageWithContext): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logName: String
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def maxRetryAttemptsForFlow(flowName: TableIdentifier): Int
- Definition Classes
- GraphExecution
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- def planAndStartFlow(flow: ResolvedFlow): Option[FlowExecution]
Plans the logical
ResolvedFlow
into aFlowExecution
and then starts executing it.Plans the logical
ResolvedFlow
into aFlowExecution
and then starts executing it. Implementation note: Thread safe- returns
None if the flow planner decided that there is no actual update required here. Otherwise returns the corresponding physical flow.
- Definition Classes
- GraphExecution
- def start(): Unit
Starts the execution of flows in
graphForExecution
.Starts the execution of flows in
graphForExecution
. Does not block.- Definition Classes
- TriggeredGraphExecution → GraphExecution
- def stop(): Unit
Stops this execution by stopping all streams and terminating any other resources.
Stops 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.
- Definition Classes
- TriggeredGraphExecution → GraphExecution
- def stopFlow(pf: FlowExecution): Unit
Stops execution of a
FlowExecution
.Stops execution of a
FlowExecution
.- Definition Classes
- GraphExecution
- def stopThread(thread: Thread): Unit
Stop a thread timeout.
Stop a thread timeout.
- Definition Classes
- GraphExecution
- def streamTrigger(flow: Flow): Trigger
The
Trigger
configuration for a streaming flow.The
Trigger
configuration for a streaming flow.- Definition Classes
- TriggeredGraphExecution → GraphExecution
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toString(): String
- Definition Classes
- AnyRef → Any
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- def withLogContext(context: Map[String, String])(body: => Unit): Unit
- Attributes
- protected
- Definition Classes
- Logging
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)