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 SummaryConstructorsConstructorDescriptionUnresolvedPipelineException(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 SummaryModifier and TypeMethodDescriptionscala.Option<String>abstract static Rapply(T1 v1, T2 v2, T3 v3, T4 v4) scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> graph()static StringtoString()Methods inherited from class org.apache.spark.sql.AnalysisExceptioncause, context, copy, errorClass, getCondition, getMessage, getMessageParameters, getQueryContext, getSimpleMessage, line, message, messageParameters, origin, startPosition, withPositionMethods inherited from class java.lang.ThrowableaddSuppressed, fillInStackTrace, getCause, getLocalizedMessage, getStackTrace, getSuppressed, initCause, printStackTrace, printStackTrace, printStackTrace, setStackTrace, toStringMethods inherited from class java.lang.Objectequals, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface scala.EqualscanEqual, equalsMethods inherited from interface scala.ProductproductArity, productElement, productElementName, productElementNames, productIterator, productPrefixMethods inherited from interface org.apache.spark.SparkThrowablegetErrorClass, getSqlState, isInternalError
- 
Constructor Details- 
UnresolvedPipelineExceptionpublic 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- 
applypublic abstract static R apply(T1 v1, T2 v2, T3 v3, T4 v4) 
- 
toString
- 
graph
- 
directFailurespublic scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> directFailures()
- 
downstreamFailurespublic scala.collection.immutable.Map<org.apache.spark.sql.catalyst.TableIdentifier,Throwable> downstreamFailures()
- 
additionalHint
 
-