Class FlowFunctionResult

Object
org.apache.spark.sql.pipelines.graph.FlowFunctionResult
All Implemented Interfaces:
Serializable, scala.Equals, scala.Product

public class FlowFunctionResult extends Object implements scala.Product, Serializable
Holds the DataFrame returned by a FlowFunction along with the inputs used to construct it. param: batchInputs the complete inputs read by the flow param: streamingInputs the incremental inputs read by the flow param: usedExternalInputs the identifiers of the external inputs read by the flow param: dataFrame the DataFrame expression executed by the flow if the flow can be resolved
See Also:
  • Constructor Summary

    Constructors
    Constructor
    Description
    FlowFunctionResult(scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> requestedInputs, scala.collection.immutable.Set<ResolvedInput> batchInputs, scala.collection.immutable.Set<ResolvedInput> streamingInputs, scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> usedExternalInputs, scala.util.Try<org.apache.spark.sql.classic.Dataset<Row>> dataFrame, scala.collection.immutable.Map<String,String> sqlConf, scala.collection.immutable.Seq<AnalysisWarning> analysisWarnings)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    scala.collection.immutable.Seq<AnalysisWarning>
     
    abstract static R
    apply(T1 v1, T2 v2, T3 v3, T4 v4, T5 v5, T6 v6, T7 v7)
     
    scala.collection.immutable.Set<ResolvedInput>
     
    scala.util.Try<org.apache.spark.sql.classic.Dataset<Row>>
     
    scala.collection.immutable.Seq<Throwable>
    Returns errors that occurred when attempting to analyze this Flow.
    scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier>
    Returns the names of all of the Inputs used when resolving this Flow.
    scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier>
     
    final boolean
    Whether this Flow is successfully analyzed.
    scala.collection.immutable.Map<String,String>
     
    scala.collection.immutable.Set<ResolvedInput>
     
    static String
     
    scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier>
     

    Methods inherited from class java.lang.Object

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

    Methods inherited from interface scala.Equals

    canEqual, equals

    Methods inherited from interface scala.Product

    productArity, productElement, productElementName, productElementNames, productIterator, productPrefix
  • Constructor Details

    • FlowFunctionResult

      public FlowFunctionResult(scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> requestedInputs, scala.collection.immutable.Set<ResolvedInput> batchInputs, scala.collection.immutable.Set<ResolvedInput> streamingInputs, scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> usedExternalInputs, scala.util.Try<org.apache.spark.sql.classic.Dataset<Row>> dataFrame, scala.collection.immutable.Map<String,String> sqlConf, scala.collection.immutable.Seq<AnalysisWarning> analysisWarnings)
  • Method Details

    • apply

      public abstract static R apply(T1 v1, T2 v2, T3 v3, T4 v4, T5 v5, T6 v6, T7 v7)
    • toString

      public static String toString()
    • requestedInputs

      public scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> requestedInputs()
    • batchInputs

      public scala.collection.immutable.Set<ResolvedInput> batchInputs()
    • streamingInputs

      public scala.collection.immutable.Set<ResolvedInput> streamingInputs()
    • usedExternalInputs

      public scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> usedExternalInputs()
    • dataFrame

      public scala.util.Try<org.apache.spark.sql.classic.Dataset<Row>> dataFrame()
    • sqlConf

      public scala.collection.immutable.Map<String,String> sqlConf()
    • analysisWarnings

      public scala.collection.immutable.Seq<AnalysisWarning> analysisWarnings()
    • inputs

      public scala.collection.immutable.Set<org.apache.spark.sql.catalyst.TableIdentifier> inputs()
      Returns the names of all of the Inputs used when resolving this Flow. If the flow failed to resolve, we return the all the datasets that were requested when evaluating the flow.
      Returns:
      (undocumented)
    • failure

      public scala.collection.immutable.Seq<Throwable> failure()
      Returns errors that occurred when attempting to analyze this Flow.
    • resolved

      public final boolean resolved()
      Whether this Flow is successfully analyzed.