Class GraphErrors

Object
org.apache.spark.sql.pipelines.graph.GraphErrors

public class GraphErrors extends Object
Collection of errors that can be thrown during graph resolution / analysis.
  • Constructor Details

    • GraphErrors

      public GraphErrors()
  • Method Details

    • pipelineLocalDatasetNotDefinedError

      public static SparkException pipelineLocalDatasetNotDefinedError(String datasetName)
      Throws when a dataset is marked as internal but is not defined in the graph.

      Parameters:
      datasetName - the name of the dataset that is not defined
      Returns:
      (undocumented)
    • invalidNameInUseCommandError

      public static SparkException invalidNameInUseCommandError(String command, String name, String reason)
      Throws when the catalog or schema name in the "USE CATALOG | SCHEMA" command is invalid

      Parameters:
      command - string "USE CATALOG" or "USE SCHEMA"
      name - the invalid catalog or schema name
      reason - the reason why the name is invalid
      Returns:
      (undocumented)
    • unresolvedTablePath

      public static SparkException unresolvedTablePath(org.apache.spark.sql.catalyst.TableIdentifier identifier)
      Throws when a table path is unresolved, i.e. the table identifier does not exist in the catalog.

      Parameters:
      identifier - the unresolved table identifier
      Returns:
      (undocumented)
    • incompatibleUserSpecifiedAndInferredSchemasError

      public static AnalysisException incompatibleUserSpecifiedAndInferredSchemasError(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier, DatasetType datasetType, StructType specifiedSchema, StructType inferredSchema, scala.Option<Throwable> cause)
      Throws an error if the user-specified schema and the inferred schema are not compatible.

      Parameters:
      tableIdentifier - the identifier of the table that was not found
      datasetType - (undocumented)
      specifiedSchema - (undocumented)
      inferredSchema - (undocumented)
      cause - (undocumented)
      Returns:
      (undocumented)
    • unableToInferSchemaError

      public static AnalysisException unableToInferSchemaError(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier, StructType inferredSchema, StructType incompatibleSchema, scala.Option<Throwable> cause)
      Throws if the latest inferred schema for a pipeline table is not compatible with the table's existing schema.

      Parameters:
      tableIdentifier - the identifier of the table that was not found
      inferredSchema - (undocumented)
      incompatibleSchema - (undocumented)
      cause - (undocumented)
      Returns:
      (undocumented)