Interface ResolutionCompletedFlow

All Superinterfaces:
Flow, GraphElement, org.apache.spark.internal.Logging
All Known Subinterfaces:
ResolvedFlow
All Known Implementing Classes:
AppendOnceFlow, CompleteFlow, ResolutionFailedFlow, StreamingFlow

public interface ResolutionCompletedFlow extends Flow
A Flow whose flow function has been invoked, meaning either: - Its output schema and dependencies are known. - It failed to resolve.
  • 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
  • Method Summary

    Modifier and Type
    Method
    Description
    scala.Option<String>
    The comment associated with this flow
    org.apache.spark.sql.catalyst.TableIdentifier
    The dataset that this Flow represents a write to.
     
    The FlowFunction containing the user's query.
     
    org.apache.spark.sql.catalyst.TableIdentifier
    Returns the unique identifier for this GraphElement.
    Contains provenance to tie back this GraphElement to the user code that defined it.
    The current query context (catalog and database) when the query is defined.
    scala.collection.immutable.Map<String,String>
     

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

    once

    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
  • Method Details

    • comment

      scala.Option<String> comment()
      Description copied from interface: Flow
      The comment associated with this flow
      Specified by:
      comment in interface Flow
    • destinationIdentifier

      org.apache.spark.sql.catalyst.TableIdentifier destinationIdentifier()
      Description copied from interface: Flow
      The dataset that this Flow represents a write to.
      Specified by:
      destinationIdentifier in interface Flow
      Returns:
      (undocumented)
    • flow

    • func

      FlowFunction func()
      Description copied from interface: Flow
      The FlowFunction containing the user's query.
      Specified by:
      func in interface Flow
    • funcResult

      FlowFunctionResult funcResult()
    • identifier

      org.apache.spark.sql.catalyst.TableIdentifier identifier()
      Description copied from interface: GraphElement
      Returns the unique identifier for this GraphElement.
      Specified by:
      identifier in interface Flow
      Specified by:
      identifier in interface GraphElement
    • origin

      QueryOrigin origin()
      Description copied from interface: GraphElement
      Contains provenance to tie back this GraphElement to the user code that defined it.

      This must be set when a GraphElement is directly created by some user code. Subsequently, this initial origin must be propagated as is without modification. If this GraphElement is copied or converted to a different type, then this origin must be copied as is.

      Specified by:
      origin in interface GraphElement
      Returns:
      (undocumented)
    • queryContext

      QueryContext queryContext()
      Description copied from interface: Flow
      The current query context (catalog and database) when the query is defined.
      Specified by:
      queryContext in interface Flow
    • sqlConf

      scala.collection.immutable.Map<String,String> sqlConf()
      Specified by:
      sqlConf in interface Flow