Class AppendOnceFlow

Object
org.apache.spark.sql.pipelines.graph.AppendOnceFlow
All Implemented Interfaces:
org.apache.spark.internal.Logging, Flow, GraphElement, Input, ResolutionCompletedFlow, ResolvedFlow

public class AppendOnceFlow extends Object implements ResolvedFlow
A Flow that reads source[s] completely and appends data to the target, just once.
  • Nested Class Summary

    Nested classes/interfaces inherited from interface org.apache.spark.internal.Logging

    org.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
  • Constructor Summary

    Constructors
    Constructor
    Description
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.spark.sql.catalyst.TableIdentifier
    The dataset that this Flow represents a write to.
     
     
    org.apache.spark.sql.catalyst.TableIdentifier
    Returns the unique identifier for this GraphElement.
    boolean
    Whether this is a ONCE flow.

    Methods inherited from class java.lang.Object

    equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface org.apache.spark.sql.pipelines.graph.GraphElement

    displayName, spark

    Methods inherited from interface org.apache.spark.internal.Logging

    initializeForcefully, 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, withLogContext

    Methods inherited from interface org.apache.spark.sql.pipelines.graph.ResolutionCompletedFlow

    comment, func, origin, queryContext, sqlConf

    Methods inherited from interface org.apache.spark.sql.pipelines.graph.ResolvedFlow

    df, inputs, load, schema