Class PipelineUpdateContextImpl
Object
org.apache.spark.sql.pipelines.graph.PipelineUpdateContextImpl
- All Implemented Interfaces:
PipelineUpdateContext
An implementation of the PipelineUpdateContext trait used in production.
param: unresolvedGraph The graph (unresolved) to be executed in this update.
param: eventCallback A callback function to be called when an event is added to the event buffer.
param: refreshTables Filter for which tables should be refreshed when performing this update.
param: fullRefreshTables Filter for which tables should be full refreshed
when performing this update.
-
Constructor Summary
ConstructorsConstructorDescriptionPipelineUpdateContextImpl(DataflowGraph unresolvedGraph, scala.Function1<PipelineEvent, scala.runtime.BoxedUnit> eventCallback, TableFilter refreshTables, TableFilter fullRefreshTables, String storageRoot) -
Method Summary
Modifier and TypeMethodDescriptionscala.Function1<PipelineEvent,scala.runtime.BoxedUnit> Callback to invoke for internal events that are emitted during a run of a pipeline.Emits internal flow progress events into the event buffer.Filter for which tables should be full refreshed when performing this update.Defines operations relates to end to end execution of a `DataflowGraph`.Filter for which tables should be refreshed when performing this update.org.apache.spark.sql.classic.SparkSessionspark()The SparkSession for this update.The root storage location for pipeline metadata, including checkpoints for streaming flows.The unresolved graph for this update.Methods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.spark.sql.pipelines.graph.PipelineUpdateContext
refreshFlows
-
Constructor Details
-
PipelineUpdateContextImpl
public PipelineUpdateContextImpl(DataflowGraph unresolvedGraph, scala.Function1<PipelineEvent, scala.runtime.BoxedUnit> eventCallback, TableFilter refreshTables, TableFilter fullRefreshTables, String storageRoot)
-
-
Method Details
-
pipelineExecution
Description copied from interface:PipelineUpdateContextDefines operations relates to end to end execution of a `DataflowGraph`.- Specified by:
pipelineExecutionin interfacePipelineUpdateContext
-
unresolvedGraph
Description copied from interface:PipelineUpdateContextThe unresolved graph for this update.- Specified by:
unresolvedGraphin interfacePipelineUpdateContext
-
eventCallback
Description copied from interface:PipelineUpdateContextCallback to invoke for internal events that are emitted during a run of a pipeline.- Specified by:
eventCallbackin interfacePipelineUpdateContext
-
refreshTables
Description copied from interface:PipelineUpdateContextFilter for which tables should be refreshed when performing this update.- Specified by:
refreshTablesin interfacePipelineUpdateContext
-
fullRefreshTables
Description copied from interface:PipelineUpdateContextFilter for which tables should be full refreshed when performing this update.- Specified by:
fullRefreshTablesin interfacePipelineUpdateContext
-
storageRoot
Description copied from interface:PipelineUpdateContextThe root storage location for pipeline metadata, including checkpoints for streaming flows.- Specified by:
storageRootin interfacePipelineUpdateContext- Returns:
- (undocumented)
-
spark
public org.apache.spark.sql.classic.SparkSession spark()Description copied from interface:PipelineUpdateContextThe SparkSession for this update.- Specified by:
sparkin interfacePipelineUpdateContext
-
flowProgressEventLogger
Description copied from interface:PipelineUpdateContextEmits internal flow progress events into the event buffer.- Specified by:
flowProgressEventLoggerin interfacePipelineUpdateContext
-
resetCheckpointFlows
- Specified by:
resetCheckpointFlowsin interfacePipelineUpdateContext
-