Class StreamingTableWrite
Object
org.apache.spark.sql.pipelines.graph.StreamingTableWrite
- All Implemented Interfaces:
- org.apache.spark.internal.Logging,- FlowExecution,- StreamingFlowExecution
A `StreamingFlowExecution` that writes a streaming `DataFrame` to a `Table`.
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.apache.spark.internal.Loggingorg.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
- 
Constructor SummaryConstructorsConstructorDescriptionStreamingTableWrite(org.apache.spark.sql.catalyst.TableIdentifier identifier, ResolvedFlow flow, DataflowGraph graph, PipelineUpdateContext updateContext, String checkpointPath, Trigger trigger, Table destination, scala.collection.immutable.Map<String, String> sqlConf) 
- 
Method SummaryModifier and TypeMethodDescriptionStructured Streaming checkpoint.The destination that this `FlowExecution` is writing to.scala.concurrent.ExecutionContextThe thread execution context for the current `FlowExecution`.flow()The `ResolvedFlow` that this `StreamingFlowExecution` is executing.Origin to use when recording events for this flow.graph()org.apache.spark.sql.catalyst.TableIdentifierIdentifier of this physical flowsqlConf()Spark confs that must be set when starting this flow.Starts a stream and returns its streaming query.trigger()Structured Streaming trigger.Context about this pipeline update.Methods inherited from class java.lang.Objectequals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.spark.sql.pipelines.graph.FlowExecutiondisplayName, exception, executeAsync, getFuture, isCompleted, spark, stopMethods 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, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq, withLogContextMethods inherited from interface org.apache.spark.sql.pipelines.graph.StreamingFlowExecutionexecuteInternal, isStreaming
- 
Constructor Details- 
StreamingTableWritepublic StreamingTableWrite(org.apache.spark.sql.catalyst.TableIdentifier identifier, ResolvedFlow flow, DataflowGraph graph, PipelineUpdateContext updateContext, String checkpointPath, Trigger trigger, Table destination, scala.collection.immutable.Map<String, String> sqlConf) 
 
- 
- 
Method Details- 
checkpointPathDescription copied from interface:StreamingFlowExecutionStructured Streaming checkpoint.- Specified by:
- checkpointPathin interface- StreamingFlowExecution
 
- 
destinationDescription copied from interface:FlowExecutionThe destination that this `FlowExecution` is writing to.- Specified by:
- destinationin interface- FlowExecution
 
- 
executionContextpublic scala.concurrent.ExecutionContext executionContext()Description copied from interface:FlowExecutionThe thread execution context for the current `FlowExecution`.- Specified by:
- executionContextin interface- FlowExecution
 
- 
flowDescription copied from interface:StreamingFlowExecutionThe `ResolvedFlow` that this `StreamingFlowExecution` is executing.- Specified by:
- flowin interface- StreamingFlowExecution
 
- 
getOriginDescription copied from interface:FlowExecutionOrigin to use when recording events for this flow.- Specified by:
- getOriginin interface- FlowExecution
- Returns:
- (undocumented)
 
- 
graph
- 
identifierpublic org.apache.spark.sql.catalyst.TableIdentifier identifier()Description copied from interface:FlowExecutionIdentifier of this physical flow- Specified by:
- identifierin interface- FlowExecution
 
- 
sqlConfDescription copied from interface:StreamingFlowExecutionSpark confs that must be set when starting this flow.- Specified by:
- sqlConfin interface- StreamingFlowExecution
 
- 
startStreamDescription copied from interface:StreamingFlowExecutionStarts a stream and returns its streaming query.- Specified by:
- startStreamin interface- StreamingFlowExecution
 
- 
triggerDescription copied from interface:StreamingFlowExecutionStructured Streaming trigger.- Specified by:
- triggerin interface- StreamingFlowExecution
 
- 
updateContextDescription copied from interface:FlowExecutionContext about this pipeline update.- Specified by:
- updateContextin interface- FlowExecution
 
 
-