Class UnresolvedPipelineException

Object
Throwable
Exception
org.apache.spark.sql.AnalysisException
org.apache.spark.sql.pipelines.graph.UnresolvedPipelineException
All Implemented Interfaces:
Serializable, SparkThrowable, org.apache.spark.sql.catalyst.trees.WithOrigin, scala.Equals, scala.Product

public class UnresolvedPipelineException extends AnalysisException implements scala.Product, Serializable
Exception raised when a pipeline has one or more flows that cannot be resolved

param: directFailures Mapping between the name of flows that failed to resolve (due to an error in that flow) and the error that occurred when attempting to resolve them param: downstreamFailures Mapping between the name of flows that failed to resolve (because they failed to read from other unresolved flows) and the error that occurred when attempting to resolve them

See Also:
  • Constructor Details

    • UnresolvedPipelineException

      public UnresolvedPipelineException(DataflowGraph graph, scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> directFailures, scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> downstreamFailures, scala.Option<String> additionalHint)
  • Method Details

    • apply

      public abstract static R apply(T1 v1, T2 v2, T3 v3, T4 v4)
    • toString

      public static String toString()
    • graph

      public DataflowGraph graph()
    • directFailures

      public scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> directFailures()
    • downstreamFailures

      public scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> downstreamFailures()
    • additionalHint

      public scala.Option<String> additionalHint()