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. case class AliasViewChild(conf: SQLConf) extends Rule[LogicalPlan] with CastSupport with Product with Serializable

    Make sure that a view's child plan produces the view's output attributes.

  2. case class AnalysisContext(defaultDatabase: Option[String] = scala.None, nestedViewDepth: Int = 0) extends Product with Serializable

    Provides a way to keep state during the analysis, this enables us to decouple the concerns of analysis environment from the catalog.

  3. implicit class AnalysisErrorAt extends AnyRef

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

  5. trait CastSupport extends AnyRef

    Mix-in trait for constructing valid Cast expressions.

  6. trait CheckAnalysis extends PredicateHelper

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

  7. class DatabaseAlreadyExistsException extends AnalysisException

    Thrown by a catalog when an item already exists.

  8. class FunctionAlreadyExistsException extends AnalysisException

  9. trait FunctionRegistry extends AnyRef

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

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

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

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

  13. class NoSuchDatabaseException extends AnalysisException

    Thrown by a catalog when an item cannot be found.

  14. class NoSuchFunctionException extends AnalysisException

  15. class NoSuchPartitionException extends AnalysisException

  16. class NoSuchPartitionsException extends AnalysisException

  17. class NoSuchPermanentFunctionException extends AnalysisException

  18. class NoSuchTableException extends AnalysisException

  19. class NoSuchTempFunctionException extends AnalysisException

  20. class PartitionAlreadyExistsException extends AnalysisException

  21. class PartitionsAlreadyExistException extends AnalysisException

  22. case class ResolveInlineTables(conf: SQLConf) extends Rule[LogicalPlan] with CastSupport with Product with Serializable

    An analyzer rule that replaces UnresolvedInlineTable with LocalRelation.

  23. case class ResolveTimeZone(conf: SQLConf) extends Rule[LogicalPlan] with Product with Serializable

    Replace TimeZoneAwareExpression without timezone id by its copy with session local time zone.

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

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

  26. class SimpleFunctionRegistry extends FunctionRegistry

  27. abstract class Star extends LeafExpression with NamedExpression

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

  28. class SubstituteUnresolvedOrdinals extends Rule[LogicalPlan]

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

  29. class TableAlreadyExistsException extends AnalysisException

  30. class TempTableAlreadyExistsException extends AnalysisException

  31. trait TypeCheckResult extends AnyRef

    Represents the result of Expression.checkInputDataTypes.

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

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

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

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

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

    Extracts a value or values from an Expression

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

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

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

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

  41. case class UnresolvedRelation(tableIdentifier: TableIdentifier) extends LeafNode with Product with Serializable

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

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

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

    A table-valued function, e.

Value Members

  1. object AnalysisContext extends Serializable

  2. object CleanupAliases extends Rule[LogicalPlan]

    Cleans up unnecessary Aliases inside the plan.

  3. object DecimalPrecision extends Rule[LogicalPlan]

    Calculates and propagates precision for fixed-precision decimals.

  4. object EliminateEventTimeWatermark extends Rule[LogicalPlan]

    Ignore event time watermark in batch query, which is only supported in Structured Streaming.

  5. object EliminateSubqueryAliases extends Rule[LogicalPlan]

    Removes SubqueryAlias operators from the plan.

  6. object EliminateUnions extends Rule[LogicalPlan]

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

  7. object EliminateView extends Rule[LogicalPlan]

    Removes View operators from the plan.

  8. object EmptyFunctionRegistry extends FunctionRegistry

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

  9. object FunctionRegistry

  10. object ResolveCreateNamedStruct extends Rule[LogicalPlan]

    Resolve a CreateNamedStruct if it contains NamePlaceholders.

  11. object ResolveHints

    Collection of rules related to hints.

  12. object ResolveTableValuedFunctions extends Rule[LogicalPlan]

    Rule that resolves table-valued function references.

  13. object SimpleAnalyzer extends Analyzer

    A trivial Analyzer with a dummy SessionCatalog and EmptyFunctionRegistry.

  14. object TimeWindowing extends Rule[LogicalPlan]

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

  15. object TypeCheckResult

  16. object TypeCoercion

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

  17. object UnresolvedAttribute extends Serializable

  18. object UnresolvedFunction extends Serializable

  19. object UnsupportedOperationChecker

    Analyzes the presence of unsupported operations in a logical plan.

  20. object UpdateOuterReferences extends Rule[LogicalPlan]

    The aggregate expressions from subquery referencing outer query block are pushed down to the outer query block for evaluation.

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

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

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