trait StreamingFlowExecution extends FlowExecution with Logging
A 'FlowExecution' that processes data statefully using Structured Streaming.
- Source
- FlowExecution.scala
- Alphabetic
- By Inheritance
- StreamingFlowExecution
- Logging
- FlowExecution
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
-   implicit  class LogStringContext extends AnyRef- Definition Classes
- Logging
 
Abstract Value Members
-   abstract  def checkpointPath: StringStructured Streaming checkpoint. 
-   abstract  def destination: OutputThe destination that this FlowExecutionis writing to.The destination that this FlowExecutionis writing to.- Definition Classes
- FlowExecution
 
-   abstract  def flow: ResolvedFlowThe ResolvedFlowthat thisStreamingFlowExecutionis executing.
-   abstract  def getOrigin: QueryOriginOrigin to use when recording events for this flow. Origin to use when recording events for this flow. - Definition Classes
- FlowExecution
 
-   abstract  def identifier: TableIdentifierIdentifier of this physical flow Identifier of this physical flow - Definition Classes
- FlowExecution
 
-   abstract  def sqlConf: Map[String, String]Spark confs that must be set when starting this flow. Spark confs that must be set when starting this flow. - Attributes
- protected
 
-   abstract  def startStream(): StreamingQueryStarts a stream and returns its streaming query. Starts a stream and returns its streaming query. - Attributes
- protected
 
-   abstract  def trigger: TriggerStructured Streaming trigger. 
-   abstract  def updateContext: PipelineUpdateContextContext about this pipeline update. Context about this pipeline update. - Definition Classes
- FlowExecution
 
Concrete 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
 
-    def MDC(key: LogKey, value: Any): MDC- Attributes
- protected
- Definition Classes
- Logging
 
-   final  def asInstanceOf[T0]: T0- Definition Classes
- Any
 
-    def clone(): AnyRef- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
 
-   final  def displayName: StringReturns a user-visible name for the flow. Returns a user-visible name for the flow. - Definition Classes
- FlowExecution
 
-   final  def eq(arg0: AnyRef): Boolean- Definition Classes
- AnyRef
 
-    def equals(arg0: AnyRef): Boolean- Definition Classes
- AnyRef → Any
 
-    def exception: Option[Throwable]Returns an optional exception that occurred during execution, if any. Returns an optional exception that occurred during execution, if any. - Definition Classes
- FlowExecution
 
-   final  def executeAsync(): UnitExecutes this FlowExecution asynchronously to perform its intended update. Executes this FlowExecution asynchronously to perform its intended update. A future that can be used to track execution status is saved, and can be retrieved with getFuture.- Definition Classes
- FlowExecution
 
-   final  def executeInternal(): Future[Unit]Executes this StreamingFlowExecutionby starting its stream with the correct scheduling pool and confs.Executes this StreamingFlowExecutionby starting its stream with the correct scheduling pool and confs.- returns
- a Future that completes when the execution is finished or stopped. 
 - Definition Classes
- StreamingFlowExecution → FlowExecution
 
-   implicit  val executionContext: ExecutionContextThe thread execution context for the current FlowExecution.The thread execution context for the current FlowExecution.- Definition Classes
- FlowExecution
 
-   final  def getClass(): Class[_ <: AnyRef]- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
 
-    def getFuture: Future[ExecutionResult]Retrieves the future that can be used to track execution status. Retrieves the future that can be used to track execution status. - Definition Classes
- FlowExecution
 
-    def getStreamingQuery: StreamingQueryVisible for testing 
-    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
 
-    def isCompleted: BooleanReturns true if and only if this FlowExecutionhas been completed with either success or an exception.Returns true if and only if this FlowExecutionhas been completed with either success or an exception.- Definition Classes
- FlowExecution
 
-   final  def isInstanceOf[T0]: Boolean- Definition Classes
- Any
 
-    def isStreaming: BooleanReturns true iff this FlowExecutionexecutes using Spark Structured Streaming.Returns true iff this FlowExecutionexecutes using Spark Structured Streaming.- Definition Classes
- StreamingFlowExecution → FlowExecution
 
-    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
 
-   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 spark: classic.SparkSessionSparkSession to execute this physical flow with. SparkSession to execute this physical flow with. The default value for streaming flows is the pipeline's spark session because the source dataframe is resolved using the pipeline's spark session, and a new session will be started implicitly by the streaming query. The default value for batch flows is a cloned spark session from the pipeline's spark session. Please make sure that the execution thread runs in a different spark session than the pipeline's spark session. - Attributes
- protected
- Definition Classes
- FlowExecution
 
-    def stop(): UnitStops execution of this FlowExecution.Stops execution of this FlowExecution. If you override this, please be sure to callsuper.stop()at the beginning of your method, so we can properly handle errors when a user tries to stop a flow.- Definition Classes
- FlowExecution
 
-   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)