Interface StreamingFlowExecution
- All Superinterfaces:
- FlowExecution,- org.apache.spark.internal.Logging
- All Known Implementing Classes:
- SinkWrite,- StreamingTableWrite
A 'FlowExecution' that processes data statefully using Structured Streaming.
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.apache.spark.internal.Loggingorg.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
- 
Method SummaryModifier and TypeMethodDescriptionStructured Streaming checkpoint.scala.concurrent.Future<scala.runtime.BoxedUnit>Executes thisStreamingFlowExecutionby starting its stream with the correct scheduling pool and confs.flow()The `ResolvedFlow` that this `StreamingFlowExecution` is executing.Visible for testingbooleanReturns true iff this `FlowExecution` executes using Spark Structured Streaming.sqlConf()Spark confs that must be set when starting this flow.Starts a stream and returns its streaming query.trigger()Structured Streaming trigger.Methods inherited from interface org.apache.spark.sql.pipelines.graph.FlowExecutiondestination, displayName, exception, executeAsync, executionContext, getFuture, getOrigin, identifier, isCompleted, spark, stop, updateContextMethods 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
- 
Method Details- 
checkpointPathString checkpointPath()Structured Streaming checkpoint.
- 
executeInternalscala.concurrent.Future<scala.runtime.BoxedUnit> executeInternal()Executes thisStreamingFlowExecutionby starting its stream with the correct scheduling pool and confs.- Specified by:
- executeInternalin interface- FlowExecution
- Returns:
- (undocumented)
 
- 
flowResolvedFlow flow()The `ResolvedFlow` that this `StreamingFlowExecution` is executing.
- 
getStreamingQueryStreamingQuery getStreamingQuery()Visible for testing
- 
isStreamingboolean isStreaming()Description copied from interface:FlowExecutionReturns true iff this `FlowExecution` executes using Spark Structured Streaming.- Specified by:
- isStreamingin interface- FlowExecution
 
- 
sqlConfSpark confs that must be set when starting this flow.
- 
startStreamStreamingQuery startStream()Starts a stream and returns its streaming query.
- 
triggerTrigger trigger()Structured Streaming trigger.
 
-