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 schema Catalog and a FunctionRegistry.

  3. trait Catalog extends AnyRef

    An interface for looking up relations by name.

  4. trait CheckAnalysis extends AnyRef

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

  5. case class DistinctAggregationRewriter(conf: CatalystConf) extends Rule[LogicalPlan] with Product with Serializable

    This rule rewrites an aggregate query with distinct aggregations into an expanded double aggregation in which the regular aggregation expressions and every distinct clause is aggregated in a separate group.

  6. case class Exists(subquery: LogicalPlan, positive: Boolean) extends LeafExpression with SubQueryExpression with Product with Serializable

    Exist subquery expression, only used in subquery predicate only.

  7. trait FunctionRegistry extends AnyRef

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

  8. case class InSubquery(child: Expression, subquery: LogicalPlan, positive: Boolean) extends UnaryExpression with SubQueryExpression with Product with Serializable

    In subquery expression, only used in subquery predicate only.

  9. 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.

  10. trait MultiInstanceRelation extends AnyRef

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

  11. class NoSuchDatabaseException extends Exception

  12. class NoSuchTableException extends Exception

    Thrown by a catalog when a table cannot be found.

  13. trait OverrideCatalog extends Catalog

    A trait that can be mixed in with other Catalogs allowing specific tables to be overridden with new logical plans.

  14. 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.

  15. 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.

  16. class SimpleCatalog extends Catalog

  17. class SimpleFunctionRegistry extends FunctionRegistry

  18. abstract class Star extends LeafExpression with NamedExpression

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

  19. trait SubQueryExpression extends Expression with Unevaluable

  20. trait TypeCheckResult extends AnyRef

    Represents the result of Expression.checkInputDataTypes.

  21. case class UnresolvedAlias(child: Expression) extends UnaryExpression with NamedExpression with Unevaluable with Product with Serializable

    Holds the expression that has yet to be aliased.

  22. 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.

  23. 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.

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

    Extracts a value or values from an Expression

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

  26. 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.

  27. 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 .

Value Members

  1. object CleanupAliases extends Rule[LogicalPlan]

    Cleans up unnecessary Aliases inside the plan.

  2. object ComputeCurrentTime extends Rule[LogicalPlan]

    Computes the current date and time to make sure we return the same result in a single query.

  3. object EliminateSubQueries extends Rule[LogicalPlan]

    Removes Subquery operators from the plan.

  4. object EmptyCatalog extends Catalog

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

  5. object EmptyFunctionRegistry extends FunctionRegistry

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

  6. object FunctionRegistry

  7. object HiveTypeCoercion

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

  8. object ResolveUpCast extends Rule[LogicalPlan]

    Replace the UpCast expression by Cast, and throw exceptions if the cast may truncate.

  9. object SimpleAnalyzer extends Analyzer

    A trivial Analyzer with an EmptyCatalog and EmptyFunctionRegistry.

  10. object TypeCheckResult

  11. object UnresolvedAttribute extends Serializable

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

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

  14. 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