org.apache.spark.sql.catalyst

analysis

package analysis

Provides a logical query plan Analyzer and supporting classes for performing analysis. Analysis consists of translating UnresolvedAttributes and UnresolvedRelations into fully typed objects using information in a schema Catalog.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. analysis
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. implicit class AnalysisErrorAt extends AnyRef

  2. class Analyzer extends RuleExecutor[LogicalPlan] with CheckAnalysis

    Provides a logical query plan analyzer, which translates UnresolvedAttributes and UnresolvedRelations into fully typed objects using information in a SessionCatalog and a FunctionRegistry.

  3. trait CheckAnalysis extends PredicateHelper

    Throws user facing errors when passed invalid queries that fail to analyze.

  4. class DatabaseAlreadyExistsException extends AnalysisException

    Thrown by a catalog when an item already exists.

  5. class FunctionAlreadyExistsException extends AnalysisException

  6. trait FunctionRegistry extends AnyRef

    A catalog for looking up user defined functions, used by an Analyzer.

  7. case class GetColumnByOrdinal(ordinal: Int, dataType: DataType) extends LeafExpression with Unevaluable with NonSQLExpression with Product with Serializable

  8. case class MultiAlias(child: Expression, names: Seq[String]) extends UnaryExpression with NamedExpression with CodegenFallback with Product with Serializable

    Used to assign new names to Generator's output, such as hive udtf.

  9. trait MultiInstanceRelation extends AnyRef

    A trait that should be mixed into query operators where a single instance might appear multiple times in a logical query plan.

  10. class NoSuchDatabaseException extends AnalysisException

    Thrown by a catalog when an item cannot be found.

  11. class NoSuchFunctionException extends AnalysisException

  12. class NoSuchPartitionException extends AnalysisException

  13. class NoSuchPartitionsException extends AnalysisException

  14. class NoSuchPermanentFunctionException extends AnalysisException

  15. class NoSuchTableException extends AnalysisException

  16. class NoSuchTempFunctionException extends AnalysisException

  17. class PartitionAlreadyExistsException extends AnalysisException

  18. class PartitionsAlreadyExistException extends AnalysisException

  19. case class ResolvedStar(expressions: Seq[NamedExpression]) extends Star with Unevaluable with Product with Serializable

    Represents all the resolved input attributes to a given relational operator.

  20. type Resolver = (String, String) ⇒ Boolean

    Resolver should return true if the first string refers to the same entity as the second string.

    Resolver should return true if the first string refers to the same entity as the second string. For example, by using case insensitive equality.

  21. class SimpleFunctionRegistry extends FunctionRegistry

  22. abstract class Star extends LeafExpression with NamedExpression

    Represents all of the input attributes to a given relational operator, for example in "SELECT * FROM .

  23. class SubstituteUnresolvedOrdinals extends Rule[LogicalPlan]

    Replaces ordinal in 'order by' or 'group by' with UnresolvedOrdinal expression.

  24. class TableAlreadyExistsException extends AnalysisException

  25. class TempFunctionAlreadyExistsException extends AnalysisException

  26. class TempTableAlreadyExistsException extends AnalysisException

  27. trait TypeCheckResult extends AnyRef

    Represents the result of Expression.checkInputDataTypes.

  28. case class UnresolvedAlias(child: Expression, aliasFunc: Option[(Expression) ⇒ String] = scala.None) extends UnaryExpression with NamedExpression with Unevaluable with Product with Serializable

    Holds the expression that has yet to be aliased.

  29. case class UnresolvedAttribute(nameParts: Seq[String]) extends Attribute with Unevaluable with Product with Serializable

    Holds the name of an attribute that has yet to be resolved.

  30. case class UnresolvedDeserializer(deserializer: Expression, inputAttributes: Seq[Attribute] = immutable.this.Nil) extends UnaryExpression with Unevaluable with NonSQLExpression with Product with Serializable

    Holds the deserializer expression and the attributes that are available during the resolution for it.

  31. class UnresolvedException[TreeType <: TreeNode[_]] extends TreeNodeException[TreeType]

    Thrown when an invalid attempt is made to access a property of a tree that has yet to be fully resolved.

  32. case class UnresolvedExtractValue(child: Expression, extraction: Expression) extends UnaryExpression with Unevaluable with Product with Serializable

    Extracts a value or values from an Expression

  33. case class UnresolvedFunction(name: FunctionIdentifier, children: Seq[Expression], isDistinct: Boolean) extends Expression with Unevaluable with Product with Serializable

  34. case class UnresolvedGenerator(name: FunctionIdentifier, children: Seq[Expression]) extends Expression with Generator with Product with Serializable

    Represents an unresolved generator, which will be created by the parser for the org.apache.spark.sql.catalyst.plans.logical.Generate operator.

  35. case class UnresolvedInlineTable(names: Seq[String], rows: Seq[Seq[Expression]]) extends LeafNode with Product with Serializable

    An inline table that has not been resolved yet.

  36. case class UnresolvedOrdinal(ordinal: Int) extends LeafExpression with Unevaluable with NonSQLExpression with Product with Serializable

    Represents unresolved ordinal used in order by or group by.

  37. case class UnresolvedRelation(tableIdentifier: TableIdentifier, alias: Option[String] = scala.None) extends LeafNode with Product with Serializable

    Holds the name of a relation that has yet to be looked up in a catalog.

  38. case class UnresolvedStar(target: Option[Seq[String]]) extends Star with Unevaluable with Product with Serializable

    Represents all of the input attributes to a given relational operator, for example in "SELECT * FROM .

  39. case class UnresolvedTableValuedFunction(functionName: String, functionArgs: Seq[Expression]) extends LeafNode with Product with Serializable

    A table-valued function, e.

Value Members

  1. object CleanupAliases extends Rule[LogicalPlan]

    Cleans up unnecessary Aliases inside the plan.

  2. object DecimalPrecision extends Rule[LogicalPlan]

    Calculates and propagates precision for fixed-precision decimals.

  3. object EliminateSubqueryAliases extends Rule[LogicalPlan]

    Removes SubqueryAlias operators from the plan.

  4. object EliminateUnions extends Rule[LogicalPlan]

    Removes Union operators from the plan if it just has one child.

  5. object EmptyFunctionRegistry extends FunctionRegistry

    A trivial catalog that returns an error when a function is requested.

  6. object FunctionRegistry

  7. object ResolveCreateNamedStruct extends Rule[LogicalPlan]

    Resolve a CreateNamedStruct if it contains NamePlaceholders.

  8. object ResolveInlineTables extends Rule[LogicalPlan]

    An analyzer rule that replaces UnresolvedInlineTable with LocalRelation.

  9. object ResolveTableValuedFunctions extends Rule[LogicalPlan]

    Rule that resolves table-valued function references.

  10. object SimpleAnalyzer extends Analyzer

    A trivial Analyzer with a dummy SessionCatalog and EmptyFunctionRegistry.

  11. object TimeWindowing extends Rule[LogicalPlan]

    Maps a time column to multiple time windows using the Expand operator.

  12. object TypeCheckResult

  13. object TypeCoercion

    A collection of Rule that can be used to coerce differing types that participate in operations into compatible ones.

  14. object UnresolvedAttribute extends Serializable

  15. object UnresolvedFunction extends Serializable

  16. object UnsupportedOperationChecker

    Analyzes the presence of unsupported operations in a logical plan.

  17. val caseInsensitiveResolution: (String, String) ⇒ Boolean

  18. val caseSensitiveResolution: (String, String) ⇒ Boolean

  19. def withPosition[A](t: TreeNode[_])(f: ⇒ A): A

    Catches any AnalysisExceptions thrown by f and attaches t's position if any.

Inherited from AnyRef

Inherited from Any

Ungrouped