Class

org.apache.spark.sql.execution

SparkSqlAstBuilder

Related Doc: package execution

Permalink

class SparkSqlAstBuilder extends AstBuilder

Builder that converts an ANTLR ParseTree into a LogicalPlan/Expression/TableIdentifier.

Linear Supertypes
AstBuilder, Logging, SqlBaseBaseVisitor[AnyRef], SqlBaseVisitor[AnyRef], AbstractParseTreeVisitor[AnyRef], ParseTreeVisitor[AnyRef], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SparkSqlAstBuilder
  2. AstBuilder
  3. Logging
  4. SqlBaseBaseVisitor
  5. SqlBaseVisitor
  6. AbstractParseTreeVisitor
  7. ParseTreeVisitor
  8. AnyRef
  9. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SparkSqlAstBuilder(conf: SQLConf)

    Permalink

Type Members

  1. type TableHeader = (TableIdentifier, Boolean, Boolean, Boolean)

    Permalink

    Type to keep track of a table header: (identifier, isTemporary, ifNotExists, isExternal).

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def aggregateResult(arg0: AnyRef, arg1: AnyRef): AnyRef

    Permalink
    Attributes
    protected[org.antlr.v4.runtime.tree]
    Definition Classes
    AbstractParseTreeVisitor
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  7. def createStructType(ctx: ColTypeListContext): StructType

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  8. def defaultResult(): AnyRef

    Permalink
    Attributes
    protected[org.antlr.v4.runtime.tree]
    Definition Classes
    AbstractParseTreeVisitor
  9. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  10. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  11. def expression(ctx: ParserRuleContext): Expression

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  12. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  13. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  14. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  15. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  16. def isExplainableStatement(plan: LogicalPlan): Boolean

    Permalink

    Determine if a plan should be explained at all.

    Determine if a plan should be explained at all.

    Attributes
    protected
  17. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  18. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  19. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  20. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  21. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  22. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  23. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  24. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  25. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  26. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  27. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  28. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  29. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  30. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  31. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  32. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  33. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  34. def plan(tree: ParserRuleContext): LogicalPlan

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  35. def shouldVisitNextChild(arg0: RuleNode, arg1: AnyRef): Boolean

    Permalink
    Attributes
    protected[org.antlr.v4.runtime.tree]
    Definition Classes
    AbstractParseTreeVisitor
  36. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  37. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  38. def typedVisit[T](ctx: ParseTree): T

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  39. def visit(arg0: ParseTree): AnyRef

    Permalink
    Definition Classes
    AbstractParseTreeVisitor → ParseTreeVisitor
  40. def visitAddTablePartition(ctx: AddTablePartitionContext): LogicalPlan

    Permalink

    Create an AlterTableAddPartitionCommand command.

    Create an AlterTableAddPartitionCommand command.

    For example:

    ALTER TABLE table ADD [IF NOT EXISTS] PARTITION spec [LOCATION 'loc1']
    ALTER VIEW view ADD [IF NOT EXISTS] PARTITION spec

    ALTER VIEW ... ADD PARTITION ... is not supported because the concept of partitioning is associated with physical tables

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  41. def visitAggregation(arg0: AggregationContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  42. def visitAliasedQuery(ctx: AliasedQueryContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  43. def visitAliasedRelation(ctx: AliasedRelationContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  44. def visitAlterViewQuery(ctx: AlterViewQueryContext): LogicalPlan

    Permalink

    Alter the query of a view.

    Alter the query of a view. This creates a AlterViewAsCommand command.

    For example:

    ALTER VIEW [db_name.]view_name AS SELECT ...;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  45. def visitAnalyze(ctx: AnalyzeContext): LogicalPlan

    Permalink

    Create an AnalyzeTableCommand command.

    Create an AnalyzeTableCommand command. This currently only implements the NOSCAN option (other options are passed on to Hive) e.g.:

    ANALYZE TABLE table COMPUTE STATISTICS NOSCAN;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  46. def visitArithmeticBinary(ctx: ArithmeticBinaryContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  47. def visitArithmeticOperator(arg0: ArithmeticOperatorContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  48. def visitArithmeticUnary(ctx: ArithmeticUnaryContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  49. def visitBigDecimalLiteral(ctx: BigDecimalLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  50. def visitBigIntLiteral(ctx: BigIntLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  51. def visitBooleanDefault(arg0: BooleanDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  52. def visitBooleanLiteral(ctx: BooleanLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  53. def visitBooleanValue(arg0: BooleanValueContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  54. def visitBucketSpec(ctx: BucketSpecContext): BucketSpec

    Permalink

    Create a BucketSpec.

    Create a BucketSpec.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  55. def visitCacheTable(ctx: CacheTableContext): LogicalPlan

    Permalink

    Create a CacheTableCommand logical plan.

    Create a CacheTableCommand logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  56. def visitCast(ctx: CastContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  57. def visitChildren(node: RuleNode): AnyRef

    Permalink
    Definition Classes
    AstBuilder → AbstractParseTreeVisitor → ParseTreeVisitor
  58. def visitClearCache(ctx: ClearCacheContext): LogicalPlan

    Permalink

    Create a ClearCacheCommand logical plan.

    Create a ClearCacheCommand logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  59. def visitColType(ctx: ColTypeContext): StructField

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  60. def visitColTypeList(ctx: ColTypeListContext): Seq[StructField]

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  61. def visitColumnReference(ctx: ColumnReferenceContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  62. def visitComparison(ctx: ComparisonContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  63. def visitComparisonOperator(arg0: ComparisonOperatorContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  64. def visitComplexDataType(ctx: ComplexDataTypeContext): DataType

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  65. def visitConstantDefault(arg0: ConstantDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  66. def visitConstantList(ctx: ConstantListContext): Seq[String]

    Permalink

    Convert a constants list into a String sequence.

    Convert a constants list into a String sequence.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  67. def visitCreateDatabase(ctx: CreateDatabaseContext): LogicalPlan

    Permalink

    Create a CreateDatabaseCommand command.

    Create a CreateDatabaseCommand command.

    For example:

    CREATE DATABASE [IF NOT EXISTS] database_name [COMMENT database_comment]
     [LOCATION path] [WITH DBPROPERTIES (key1=val1, key2=val2, ...)]
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  68. def visitCreateFileFormat(ctx: CreateFileFormatContext): CatalogStorageFormat

    Permalink

    Create a CatalogStorageFormat for creating tables.

    Create a CatalogStorageFormat for creating tables.

    Format: STORED AS ...

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  69. def visitCreateFunction(ctx: CreateFunctionContext): LogicalPlan

    Permalink

    Create a CreateFunctionCommand command.

    Create a CreateFunctionCommand command.

    For example:

    CREATE [TEMPORARY] FUNCTION [db_name.]function_name AS class_name
     [USING JAR|FILE|ARCHIVE 'file_uri' [, JAR|FILE|ARCHIVE 'file_uri']];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  70. def visitCreateTable(ctx: CreateTableContext): LogicalPlan

    Permalink

    Create a table, returning either a CreateTableCommand or a CreateHiveTableAsSelectLogicalPlan.

    Create a table, returning either a CreateTableCommand or a CreateHiveTableAsSelectLogicalPlan.

    This is not used to create datasource tables, which is handled through "CREATE TABLE ... USING ...".

    Note: several features are currently not supported - temporary tables, bucketing, skewed columns and storage handlers (STORED BY).

    Expected format:

    CREATE [EXTERNAL] TABLE [IF NOT EXISTS] [db_name.]table_name
    [(col1[:] data_type [COMMENT col_comment], ...)]
    [COMMENT table_comment]
    [PARTITIONED BY (col2[:] data_type [COMMENT col_comment], ...)]
    [ROW FORMAT row_format]
    [STORED AS file_format]
    [LOCATION path]
    [TBLPROPERTIES (property_name=property_value, ...)]
    [AS select_statement];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  71. def visitCreateTableHeader(ctx: CreateTableHeaderContext): TableHeader

    Permalink

    Validate a create table statement and return the TableIdentifier.

    Validate a create table statement and return the TableIdentifier.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  72. def visitCreateTableLike(ctx: CreateTableLikeContext): LogicalPlan

    Permalink

    Create a CreateTableLikeCommand command.

    Create a CreateTableLikeCommand command.

    For example:

    CREATE TABLE [IF NOT EXISTS] [db_name.]table_name
    LIKE [other_db_name.]existing_table_name
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  73. def visitCreateTableUsing(ctx: CreateTableUsingContext): LogicalPlan

    Permalink

    Create a CreateTableUsing or a CreateTableUsingAsSelect logical plan.

    Create a CreateTableUsing or a CreateTableUsingAsSelect logical plan.

    TODO add bucketing and partitioning.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  74. def visitCreateTempViewUsing(ctx: CreateTempViewUsingContext): LogicalPlan

    Permalink

    Creates a CreateTempViewUsing logical plan.

    Creates a CreateTempViewUsing logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  75. def visitCreateView(ctx: CreateViewContext): LogicalPlan

    Permalink

    Create or replace a view.

    Create or replace a view. This creates a CreateViewCommand command.

    For example:

    CREATE [OR REPLACE] [TEMPORARY] VIEW [IF NOT EXISTS] [db_name.]view_name
    [(column_name [COMMENT column_comment], ...) ]
    [COMMENT view_comment]
    [TBLPROPERTIES (property_name = property_value, ...)]
    AS SELECT ...;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  76. def visitCtes(arg0: CtesContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  77. def visitDecimalLiteral(ctx: DecimalLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  78. def visitDereference(ctx: DereferenceContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  79. def visitDescribeColName(arg0: DescribeColNameContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  80. def visitDescribeDatabase(ctx: DescribeDatabaseContext): LogicalPlan

    Permalink

    Create a DescribeDatabaseCommand command.

    Create a DescribeDatabaseCommand command.

    For example:

    DESCRIBE DATABASE [EXTENDED] database;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  81. def visitDescribeFuncName(arg0: DescribeFuncNameContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  82. def visitDescribeFunction(ctx: DescribeFunctionContext): LogicalPlan

    Permalink

    Create a plan for a DESCRIBE FUNCTION command.

    Create a plan for a DESCRIBE FUNCTION command.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  83. def visitDescribeTable(ctx: DescribeTableContext): LogicalPlan

    Permalink

    Create a DescribeTableCommand logical plan.

    Create a DescribeTableCommand logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  84. def visitDoubleLiteral(ctx: DoubleLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  85. def visitDropDatabase(ctx: DropDatabaseContext): LogicalPlan

    Permalink

    Create a DropDatabaseCommand command.

    Create a DropDatabaseCommand command.

    For example:

    DROP (DATABASE|SCHEMA) [IF EXISTS] database [RESTRICT|CASCADE];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  86. def visitDropFunction(ctx: DropFunctionContext): LogicalPlan

    Permalink

    Create a DropFunctionCommand command.

    Create a DropFunctionCommand command.

    For example:

    DROP [TEMPORARY] FUNCTION [IF EXISTS] function;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  87. def visitDropTable(ctx: DropTableContext): LogicalPlan

    Permalink

    Create a DropTableCommand command.

    Create a DropTableCommand command.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  88. def visitDropTablePartitions(ctx: DropTablePartitionsContext): LogicalPlan

    Permalink

    Create an AlterTableDropPartitionCommand command

    Create an AlterTableDropPartitionCommand command

    For example:

    ALTER TABLE table DROP [IF EXISTS] PARTITION spec1[, PARTITION spec2, ...] [PURGE];
    ALTER VIEW view DROP [IF EXISTS] PARTITION spec1[, PARTITION spec2, ...];

    ALTER VIEW ... DROP PARTITION ... is not supported because the concept of partitioning is associated with physical tables

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  89. def visitErrorNode(arg0: ErrorNode): AnyRef

    Permalink
    Definition Classes
    AbstractParseTreeVisitor → ParseTreeVisitor
  90. def visitExists(ctx: ExistsContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  91. def visitExplain(ctx: ExplainContext): LogicalPlan

    Permalink

    Create an ExplainCommand logical plan.

    Create an ExplainCommand logical plan. The syntax of using this command in SQL is:

    EXPLAIN (EXTENDED | CODEGEN) SELECT * FROM ...
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  92. def visitExpression(arg0: ExpressionContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  93. def visitFailNativeCommand(ctx: FailNativeCommandContext): LogicalPlan

    Permalink

    Fail an unsupported Hive native command.

    Fail an unsupported Hive native command.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  94. def visitFrameBound(ctx: FrameBoundContext): FrameBoundary

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  95. def visitFromClause(ctx: FromClauseContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  96. def visitFunctionCall(ctx: FunctionCallContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  97. def visitFunctionName(ctx: QualifiedNameContext): FunctionIdentifier

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  98. def visitGenericFileFormat(ctx: GenericFileFormatContext): CatalogStorageFormat

    Permalink

    Resolve a HiveSerDe based on the name given and return it as a CatalogStorageFormat.

    Resolve a HiveSerDe based on the name given and return it as a CatalogStorageFormat.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  99. def visitGroupingSet(arg0: GroupingSetContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  100. def visitIdentifier(arg0: IdentifierContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  101. def visitIdentifierComment(arg0: IdentifierCommentContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  102. def visitIdentifierCommentList(arg0: IdentifierCommentListContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  103. def visitIdentifierList(ctx: IdentifierListContext): Seq[String]

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  104. def visitIdentifierSeq(ctx: IdentifierSeqContext): Seq[String]

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  105. def visitInlineTable(ctx: InlineTableContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  106. def visitInlineTableDefault1(arg0: InlineTableDefault1Context): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  107. def visitInlineTableDefault2(arg0: InlineTableDefault2Context): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  108. def visitInsertInto(arg0: InsertIntoContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  109. def visitIntegerLiteral(ctx: IntegerLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  110. def visitInterval(ctx: IntervalContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  111. def visitIntervalField(ctx: IntervalFieldContext): CalendarInterval

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  112. def visitIntervalLiteral(arg0: IntervalLiteralContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  113. def visitIntervalValue(arg0: IntervalValueContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  114. def visitJoinCriteria(arg0: JoinCriteriaContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  115. def visitJoinRelation(arg0: JoinRelationContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  116. def visitJoinType(arg0: JoinTypeContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  117. def visitLateralView(arg0: LateralViewContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  118. def visitLoadData(ctx: LoadDataContext): LogicalPlan

    Permalink

    Create a LoadDataCommand command.

    Create a LoadDataCommand command.

    For example:

    LOAD DATA [LOCAL] INPATH 'filepath' [OVERWRITE] INTO TABLE tablename
    [PARTITION (partcol1=val1, partcol2=val2 ...)]
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  119. def visitLocationSpec(ctx: LocationSpecContext): String

    Permalink

    Create location string.

    Create location string.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  120. def visitLogicalBinary(ctx: LogicalBinaryContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  121. def visitLogicalNot(ctx: LogicalNotContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  122. def visitManageResource(ctx: ManageResourceContext): LogicalPlan

    Permalink

    Create a AddFileCommand, AddJarCommand, ListFilesCommand or ListJarsCommand command depending on the requested operation on resources.

    Create a AddFileCommand, AddJarCommand, ListFilesCommand or ListJarsCommand command depending on the requested operation on resources. Expected format:

    ADD (FILE[S] <filepath ...> | JAR[S] <jarpath ...>)
    LIST (FILE[S] [filepath ...] | JAR[S] [jarpath ...])
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  123. def visitMultiInsertQuery(ctx: MultiInsertQueryContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  124. def visitMultiInsertQueryBody(arg0: MultiInsertQueryBodyContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  125. def visitNamedExpression(ctx: NamedExpressionContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  126. def visitNamedExpressionSeq(arg0: NamedExpressionSeqContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  127. def visitNamedQuery(ctx: NamedQueryContext): SubqueryAlias

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  128. def visitNamedWindow(arg0: NamedWindowContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  129. def visitNestedConstantList(ctx: NestedConstantListContext): Seq[Seq[String]]

    Permalink

    Convert a nested constants list into a sequence of string sequences.

    Convert a nested constants list into a sequence of string sequences.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  130. def visitNonOptionalPartitionSpec(ctx: PartitionSpecContext): Map[String, String]

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  131. def visitNonReserved(arg0: NonReservedContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  132. def visitNullLiteral(ctx: NullLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  133. def visitNumericLiteral(arg0: NumericLiteralContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  134. def visitOrderedIdentifier(arg0: OrderedIdentifierContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  135. def visitOrderedIdentifierList(arg0: OrderedIdentifierListContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  136. def visitParenthesizedExpression(ctx: ParenthesizedExpressionContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  137. def visitPartitionSpec(ctx: PartitionSpecContext): Map[String, Option[String]]

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  138. def visitPartitionSpecLocation(arg0: PartitionSpecLocationContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  139. def visitPartitionVal(arg0: PartitionValContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  140. def visitPredicate(arg0: PredicateContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  141. def visitPredicateOperator(arg0: PredicateOperatorContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  142. def visitPredicated(ctx: PredicatedContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  143. def visitPrimitiveDataType(ctx: PrimitiveDataTypeContext): DataType

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  144. def visitQualifiedName(arg0: QualifiedNameContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  145. def visitQuery(ctx: QueryContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  146. def visitQueryOrganization(arg0: QueryOrganizationContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  147. def visitQueryPrimaryDefault(arg0: QueryPrimaryDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  148. def visitQuerySpecification(ctx: QuerySpecificationContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  149. def visitQueryTermDefault(arg0: QueryTermDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  150. def visitQuotedIdentifier(arg0: QuotedIdentifierContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  151. def visitQuotedIdentifierAlternative(arg0: QuotedIdentifierAlternativeContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  152. def visitRecoverPartitions(ctx: RecoverPartitionsContext): LogicalPlan

    Permalink

    Create an AlterTableRecoverPartitionsCommand command

    Create an AlterTableRecoverPartitionsCommand command

    For example:

    ALTER TABLE table RECOVER PARTITIONS;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  153. def visitRefreshResource(ctx: RefreshResourceContext): LogicalPlan

    Permalink

    Create a RefreshTable logical plan.

    Create a RefreshTable logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  154. def visitRefreshTable(ctx: RefreshTableContext): LogicalPlan

    Permalink

    Create a RefreshTable logical plan.

    Create a RefreshTable logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  155. def visitRelation(ctx: RelationContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  156. def visitRenameTable(ctx: RenameTableContext): LogicalPlan

    Permalink

    Create a AlterTableRenameCommand command.

    Create a AlterTableRenameCommand command.

    For example:

    ALTER TABLE table1 RENAME TO table2;
    ALTER VIEW view1 RENAME TO view2;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  157. def visitRenameTablePartition(ctx: RenameTablePartitionContext): LogicalPlan

    Permalink

    Create an AlterTableRenamePartitionCommand command

    Create an AlterTableRenamePartitionCommand command

    For example:

    ALTER TABLE table PARTITION spec1 RENAME TO PARTITION spec2;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  158. def visitRepairTable(ctx: RepairTableContext): LogicalPlan

    Permalink

    Create a AlterTableRecoverPartitionsCommand command.

    Create a AlterTableRecoverPartitionsCommand command.

    For example:

    MSCK REPAIR TABLE tablename
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  159. def visitResetConfiguration(ctx: ResetConfigurationContext): LogicalPlan

    Permalink

    Create a ResetCommand logical plan.

    Create a ResetCommand logical plan. Example SQL :

    RESET;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  160. def visitResource(arg0: ResourceContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  161. def visitRowConstructor(ctx: RowConstructorContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  162. def visitRowFormatDelimited(ctx: RowFormatDelimitedContext): CatalogStorageFormat

    Permalink

    Create a delimited row format properties object.

    Create a delimited row format properties object.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  163. def visitRowFormatSerde(ctx: RowFormatSerdeContext): CatalogStorageFormat

    Permalink

    Create SERDE row format name and properties pair.

    Create SERDE row format name and properties pair.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  164. def visitSample(arg0: SampleContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  165. def visitScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  166. def visitSearchedCase(ctx: SearchedCaseContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  167. def visitSetConfiguration(ctx: SetConfigurationContext): LogicalPlan

    Permalink

    Create a SetCommand logical plan.

    Create a SetCommand logical plan.

    Note that we assume that everything after the SET keyword is assumed to be a part of the key-value pair. The split between key and value is made by searching for the first = character in the raw string.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  168. def visitSetDatabaseProperties(ctx: SetDatabasePropertiesContext): LogicalPlan

    Permalink

    Create an AlterDatabasePropertiesCommand command.

    Create an AlterDatabasePropertiesCommand command.

    For example:

    ALTER (DATABASE|SCHEMA) database SET DBPROPERTIES (property_name=property_value, ...);
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  169. def visitSetOperation(ctx: SetOperationContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  170. def visitSetQuantifier(arg0: SetQuantifierContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  171. def visitSetTableLocation(ctx: SetTableLocationContext): LogicalPlan

    Permalink

    Create an AlterTableSetLocationCommand command

    Create an AlterTableSetLocationCommand command

    For example:

    ALTER TABLE table [PARTITION spec] SET LOCATION "loc";
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  172. def visitSetTableProperties(ctx: SetTablePropertiesContext): LogicalPlan

    Permalink

    Create an AlterTableSetPropertiesCommand command.

    Create an AlterTableSetPropertiesCommand command.

    For example:

    ALTER TABLE table SET TBLPROPERTIES ('comment' = new_comment);
    ALTER VIEW view SET TBLPROPERTIES ('comment' = new_comment);
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  173. def visitSetTableSerDe(ctx: SetTableSerDeContext): LogicalPlan

    Permalink

    Create an AlterTableSerDePropertiesCommand command.

    Create an AlterTableSerDePropertiesCommand command.

    For example:

    ALTER TABLE table [PARTITION spec] SET SERDE serde_name [WITH SERDEPROPERTIES props];
    ALTER TABLE table [PARTITION spec] SET SERDEPROPERTIES serde_properties;
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  174. def visitShowColumns(ctx: ShowColumnsContext): LogicalPlan

    Permalink

    A command for users to list the column names for a table.

    A command for users to list the column names for a table. This function creates a ShowColumnsCommand logical plan.

    The syntax of using this command in SQL is:

    SHOW COLUMNS (FROM | IN) table_identifier [(FROM | IN) database];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  175. def visitShowCreateTable(ctx: ShowCreateTableContext): LogicalPlan

    Permalink

    Creates a ShowCreateTableCommand

    Creates a ShowCreateTableCommand

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  176. def visitShowDatabases(ctx: ShowDatabasesContext): LogicalPlan

    Permalink

    Create a ShowDatabasesCommand logical plan.

    Create a ShowDatabasesCommand logical plan. Example SQL:

    SHOW (DATABASES|SCHEMAS) [LIKE 'identifier_with_wildcards'];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  177. def visitShowFunctions(ctx: ShowFunctionsContext): LogicalPlan

    Permalink

    Create a plan for a SHOW FUNCTIONS command.

    Create a plan for a SHOW FUNCTIONS command.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  178. def visitShowPartitions(ctx: ShowPartitionsContext): LogicalPlan

    Permalink

    A command for users to list the partition names of a table.

    A command for users to list the partition names of a table. If partition spec is specified, partitions that match the spec are returned. Otherwise an empty result set is returned.

    This function creates a ShowPartitionsCommand logical plan

    The syntax of using this command in SQL is:

    SHOW PARTITIONS table_identifier [partition_spec];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  179. def visitShowTables(ctx: ShowTablesContext): LogicalPlan

    Permalink

    Create a ShowTablesCommand logical plan.

    Create a ShowTablesCommand logical plan. Example SQL :

    SHOW TABLES [(IN|FROM) database_name] [[LIKE] 'identifier_with_wildcards'];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  180. def visitShowTblProperties(ctx: ShowTblPropertiesContext): LogicalPlan

    Permalink

    A command for users to list the properties for a table.

    A command for users to list the properties for a table. If propertyKey is specified, the value for the propertyKey is returned. If propertyKey is not specified, all the keys and their corresponding values are returned. The syntax of using this command in SQL is:

    SHOW TBLPROPERTIES table_name[('propertyKey')];
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  181. def visitSimpleCase(ctx: SimpleCaseContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  182. def visitSingleDataType(ctx: SingleDataTypeContext): DataType

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  183. def visitSingleExpression(ctx: SingleExpressionContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  184. def visitSingleInsertQuery(ctx: SingleInsertQueryContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  185. def visitSingleStatement(ctx: SingleStatementContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  186. def visitSingleTableIdentifier(ctx: SingleTableIdentifierContext): TableIdentifier

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  187. def visitSkewSpec(arg0: SkewSpecContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  188. def visitSmallIntLiteral(ctx: SmallIntLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  189. def visitSortItem(ctx: SortItemContext): SortOrder

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  190. def visitStar(ctx: StarContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  191. def visitStatementDefault(arg0: StatementDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  192. def visitStorageHandler(arg0: StorageHandlerContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  193. def visitStringConstant(ctx: ConstantContext): String

    Permalink
    Attributes
    protected
    Definition Classes
    AstBuilder
  194. def visitStringLiteral(ctx: StringLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  195. def visitSubquery(ctx: SubqueryContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  196. def visitSubqueryExpression(ctx: SubqueryExpressionContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  197. def visitSubscript(ctx: SubscriptContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  198. def visitTable(ctx: TableContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  199. def visitTableFileFormat(ctx: TableFileFormatContext): CatalogStorageFormat

    Permalink

    Create a CatalogStorageFormat.

    Create a CatalogStorageFormat.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  200. def visitTableIdentifier(ctx: TableIdentifierContext): TableIdentifier

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  201. def visitTableName(ctx: TableNameContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  202. def visitTableProperty(arg0: TablePropertyContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  203. def visitTablePropertyKey(key: TablePropertyKeyContext): String

    Permalink

    A table property key can either be String or a collection of dot separated elements.

    A table property key can either be String or a collection of dot separated elements. This function extracts the property key based on whether its a string literal or a table property identifier.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  204. def visitTablePropertyList(ctx: TablePropertyListContext): Map[String, String]

    Permalink

    Convert a table property list into a key-value map.

    Convert a table property list into a key-value map. This should be called through visitPropertyKeyValues or visitPropertyKeys.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  205. def visitTableProvider(arg0: TableProviderContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  206. def visitTableValuedFunction(ctx: TableValuedFunctionContext): LogicalPlan

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  207. def visitTerminal(arg0: TerminalNode): AnyRef

    Permalink
    Definition Classes
    AbstractParseTreeVisitor → ParseTreeVisitor
  208. def visitTimeFunctionCall(ctx: TimeFunctionCallContext): Expression

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  209. def visitTinyIntLiteral(ctx: TinyIntLiteralContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  210. def visitTruncateTable(ctx: TruncateTableContext): LogicalPlan

    Permalink

    Create a TruncateTableCommand command.

    Create a TruncateTableCommand command.

    For example:

    TRUNCATE TABLE tablename [PARTITION (partcol1=val1, partcol2=val2 ...)]
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  211. def visitTypeConstructor(ctx: TypeConstructorContext): Literal

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  212. def visitUncacheTable(ctx: UncacheTableContext): LogicalPlan

    Permalink

    Create an UncacheTableCommand logical plan.

    Create an UncacheTableCommand logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  213. def visitUnquotedIdentifier(arg0: UnquotedIdentifierContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  214. def visitUnsetTableProperties(ctx: UnsetTablePropertiesContext): LogicalPlan

    Permalink

    Create an AlterTableUnsetPropertiesCommand command.

    Create an AlterTableUnsetPropertiesCommand command.

    For example:

    ALTER TABLE table UNSET TBLPROPERTIES [IF EXISTS] ('comment', 'key');
    ALTER VIEW view UNSET TBLPROPERTIES [IF EXISTS] ('comment', 'key');
    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  215. def visitUnsupportedHiveNativeCommands(arg0: UnsupportedHiveNativeCommandsContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  216. def visitUse(ctx: UseContext): LogicalPlan

    Permalink

    Create a SetDatabaseCommand logical plan.

    Create a SetDatabaseCommand logical plan.

    Definition Classes
    SparkSqlAstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  217. def visitValueExpressionDefault(arg0: ValueExpressionDefaultContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  218. def visitWhenClause(arg0: WhenClauseContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  219. def visitWindowDef(ctx: WindowDefContext): WindowSpecDefinition

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  220. def visitWindowFrame(arg0: WindowFrameContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  221. def visitWindowRef(ctx: WindowRefContext): WindowSpecReference

    Permalink
    Definition Classes
    AstBuilder → SqlBaseBaseVisitor → SqlBaseVisitor
  222. def visitWindows(arg0: WindowsContext): AnyRef

    Permalink
    Definition Classes
    SqlBaseBaseVisitor → SqlBaseVisitor
  223. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  224. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  225. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  226. def withScriptIOSchema(ctx: QuerySpecificationContext, inRowFormat: RowFormatContext, recordWriter: Token, outRowFormat: RowFormatContext, recordReader: Token, schemaLess: Boolean): ScriptInputOutputSchema

    Permalink

    Create a ScriptInputOutputSchema.

    Create a ScriptInputOutputSchema.

    Attributes
    protected
    Definition Classes
    SparkSqlAstBuilder → AstBuilder

Inherited from AstBuilder

Inherited from Logging

Inherited from SqlBaseBaseVisitor[AnyRef]

Inherited from SqlBaseVisitor[AnyRef]

Inherited from AbstractParseTreeVisitor[AnyRef]

Inherited from ParseTreeVisitor[AnyRef]

Inherited from AnyRef

Inherited from Any

Ungrouped