Class BatchTableWrite
Object
org.apache.spark.sql.pipelines.graph.BatchTableWrite
- All Implemented Interfaces:
- FlowExecution
A `FlowExecution` that writes a batch `DataFrame` to a `Table`.
- 
Constructor SummaryConstructorsConstructorDescriptionBatchTableWrite(org.apache.spark.sql.catalyst.TableIdentifier identifier, ResolvedFlow flow, DataflowGraph graph, Table destination, PipelineUpdateContext updateContext, scala.collection.immutable.Map<String, String> sqlConf) 
- 
Method SummaryModifier and TypeMethodDescriptionThe destination that this `FlowExecution` is writing to.scala.concurrent.Future<scala.runtime.BoxedUnit>Executes this FlowExecution synchronously to perform its intended update.scala.concurrent.ExecutionContextThe thread execution context for the current `FlowExecution`.flow()Origin to use when recording events for this flow.graph()org.apache.spark.sql.catalyst.TableIdentifierIdentifier of this physical flowbooleanReturns true iff this `FlowExecution` executes using Spark Structured Streaming.sqlConf()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, stop
- 
Constructor Details- 
BatchTableWritepublic BatchTableWrite(org.apache.spark.sql.catalyst.TableIdentifier identifier, ResolvedFlow flow, DataflowGraph graph, Table destination, PipelineUpdateContext updateContext, scala.collection.immutable.Map<String, String> sqlConf) 
 
- 
- 
Method Details- 
destinationDescription copied from interface:FlowExecutionThe destination that this `FlowExecution` is writing to.- Specified by:
- destinationin interface- FlowExecution
 
- 
executeInternalpublic scala.concurrent.Future<scala.runtime.BoxedUnit> executeInternal()Description copied from interface:FlowExecutionExecutes this FlowExecution synchronously to perform its intended update. This method should be overridden by subclasses to provide the actual execution logic.- Specified by:
- executeInternalin interface- FlowExecution
- Returns:
- a Future that completes when the execution is finished or stopped.
 
- 
executionContextpublic scala.concurrent.ExecutionContext executionContext()Description copied from interface:FlowExecutionThe thread execution context for the current `FlowExecution`.- Specified by:
- executionContextin interface- FlowExecution
 
- 
flow
- 
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
 
- 
isStreamingpublic boolean isStreaming()Description copied from interface:FlowExecutionReturns true iff this `FlowExecution` executes using Spark Structured Streaming.- Specified by:
- isStreamingin interface- FlowExecution
 
- 
sqlConf
- 
updateContextDescription copied from interface:FlowExecutionContext about this pipeline update.- Specified by:
- updateContextin interface- FlowExecution
 
 
-