Trait

org.apache.spark.sql.catalyst.parser

SqlBaseVisitor

Related Doc: package parser

Permalink

trait SqlBaseVisitor[T] extends ParseTreeVisitor[T]

Linear Supertypes
ParseTreeVisitor[T], AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SqlBaseVisitor
  2. ParseTreeVisitor
  3. AnyRef
  4. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract def visit(arg0: ParseTree): T

    Permalink
    Definition Classes
    ParseTreeVisitor
  2. abstract def visitAddTablePartition(ctx: AddTablePartitionContext): T

    Permalink
  3. abstract def visitAggregation(ctx: AggregationContext): T

    Permalink
  4. abstract def visitAliasedQuery(ctx: AliasedQueryContext): T

    Permalink
  5. abstract def visitAliasedRelation(ctx: AliasedRelationContext): T

    Permalink
  6. abstract def visitAlterViewQuery(ctx: AlterViewQueryContext): T

    Permalink
  7. abstract def visitAnalyze(ctx: AnalyzeContext): T

    Permalink
  8. abstract def visitArithmeticBinary(ctx: ArithmeticBinaryContext): T

    Permalink
  9. abstract def visitArithmeticOperator(ctx: ArithmeticOperatorContext): T

    Permalink
  10. abstract def visitArithmeticUnary(ctx: ArithmeticUnaryContext): T

    Permalink
  11. abstract def visitBigIntLiteral(ctx: BigIntLiteralContext): T

    Permalink
  12. abstract def visitBooleanDefault(ctx: BooleanDefaultContext): T

    Permalink
  13. abstract def visitBooleanLiteral(ctx: BooleanLiteralContext): T

    Permalink
  14. abstract def visitBooleanValue(ctx: BooleanValueContext): T

    Permalink
  15. abstract def visitBucketSpec(ctx: BucketSpecContext): T

    Permalink
  16. abstract def visitCacheTable(ctx: CacheTableContext): T

    Permalink
  17. abstract def visitCast(ctx: CastContext): T

    Permalink
  18. abstract def visitChildren(arg0: RuleNode): T

    Permalink
    Definition Classes
    ParseTreeVisitor
  19. abstract def visitClearCache(ctx: ClearCacheContext): T

    Permalink
  20. abstract def visitColType(ctx: ColTypeContext): T

    Permalink
  21. abstract def visitColTypeList(ctx: ColTypeListContext): T

    Permalink
  22. abstract def visitColumnReference(ctx: ColumnReferenceContext): T

    Permalink
  23. abstract def visitComparison(ctx: ComparisonContext): T

    Permalink
  24. abstract def visitComparisonOperator(ctx: ComparisonOperatorContext): T

    Permalink
  25. abstract def visitComplexDataType(ctx: ComplexDataTypeContext): T

    Permalink
  26. abstract def visitConstantDefault(ctx: ConstantDefaultContext): T

    Permalink
  27. abstract def visitConstantList(ctx: ConstantListContext): T

    Permalink
  28. abstract def visitCreateDatabase(ctx: CreateDatabaseContext): T

    Permalink
  29. abstract def visitCreateFileFormat(ctx: CreateFileFormatContext): T

    Permalink
  30. abstract def visitCreateFunction(ctx: CreateFunctionContext): T

    Permalink
  31. abstract def visitCreateTable(ctx: CreateTableContext): T

    Permalink
  32. abstract def visitCreateTableHeader(ctx: CreateTableHeaderContext): T

    Permalink
  33. abstract def visitCreateTableLike(ctx: CreateTableLikeContext): T

    Permalink
  34. abstract def visitCreateTableUsing(ctx: CreateTableUsingContext): T

    Permalink
  35. abstract def visitCreateTempViewUsing(ctx: CreateTempViewUsingContext): T

    Permalink
  36. abstract def visitCreateView(ctx: CreateViewContext): T

    Permalink
  37. abstract def visitCtes(ctx: CtesContext): T

    Permalink
  38. abstract def visitDecimalLiteral(ctx: DecimalLiteralContext): T

    Permalink
  39. abstract def visitDereference(ctx: DereferenceContext): T

    Permalink
  40. abstract def visitDescribeColName(ctx: DescribeColNameContext): T

    Permalink
  41. abstract def visitDescribeDatabase(ctx: DescribeDatabaseContext): T

    Permalink
  42. abstract def visitDescribeFuncName(ctx: DescribeFuncNameContext): T

    Permalink
  43. abstract def visitDescribeFunction(ctx: DescribeFunctionContext): T

    Permalink
  44. abstract def visitDescribeTable(ctx: DescribeTableContext): T

    Permalink
  45. abstract def visitDoubleLiteral(ctx: DoubleLiteralContext): T

    Permalink
  46. abstract def visitDropDatabase(ctx: DropDatabaseContext): T

    Permalink
  47. abstract def visitDropFunction(ctx: DropFunctionContext): T

    Permalink
  48. abstract def visitDropTable(ctx: DropTableContext): T

    Permalink
  49. abstract def visitDropTablePartitions(ctx: DropTablePartitionsContext): T

    Permalink
  50. abstract def visitErrorNode(arg0: ErrorNode): T

    Permalink
    Definition Classes
    ParseTreeVisitor
  51. abstract def visitExists(ctx: ExistsContext): T

    Permalink
  52. abstract def visitExplain(ctx: ExplainContext): T

    Permalink
  53. abstract def visitExpression(ctx: ExpressionContext): T

    Permalink
  54. abstract def visitFailNativeCommand(ctx: FailNativeCommandContext): T

    Permalink
  55. abstract def visitFrameBound(ctx: FrameBoundContext): T

    Permalink
  56. abstract def visitFromClause(ctx: FromClauseContext): T

    Permalink
  57. abstract def visitFunctionCall(ctx: FunctionCallContext): T

    Permalink
  58. abstract def visitGenericFileFormat(ctx: GenericFileFormatContext): T

    Permalink
  59. abstract def visitGroupingSet(ctx: GroupingSetContext): T

    Permalink
  60. abstract def visitIdentifier(ctx: IdentifierContext): T

    Permalink
  61. abstract def visitIdentifierComment(ctx: IdentifierCommentContext): T

    Permalink
  62. abstract def visitIdentifierCommentList(ctx: IdentifierCommentListContext): T

    Permalink
  63. abstract def visitIdentifierList(ctx: IdentifierListContext): T

    Permalink
  64. abstract def visitIdentifierSeq(ctx: IdentifierSeqContext): T

    Permalink
  65. abstract def visitInlineTable(ctx: InlineTableContext): T

    Permalink
  66. abstract def visitInlineTableDefault1(ctx: InlineTableDefault1Context): T

    Permalink
  67. abstract def visitInlineTableDefault2(ctx: InlineTableDefault2Context): T

    Permalink
  68. abstract def visitInsertInto(ctx: InsertIntoContext): T

    Permalink
  69. abstract def visitIntegerLiteral(ctx: IntegerLiteralContext): T

    Permalink
  70. abstract def visitInterval(ctx: IntervalContext): T

    Permalink
  71. abstract def visitIntervalField(ctx: IntervalFieldContext): T

    Permalink
  72. abstract def visitIntervalLiteral(ctx: IntervalLiteralContext): T

    Permalink
  73. abstract def visitIntervalValue(ctx: IntervalValueContext): T

    Permalink
  74. abstract def visitJoinCriteria(ctx: JoinCriteriaContext): T

    Permalink
  75. abstract def visitJoinRelation(ctx: JoinRelationContext): T

    Permalink
  76. abstract def visitJoinType(ctx: JoinTypeContext): T

    Permalink
  77. abstract def visitLateralView(ctx: LateralViewContext): T

    Permalink
  78. abstract def visitLoadData(ctx: LoadDataContext): T

    Permalink
  79. abstract def visitLocationSpec(ctx: LocationSpecContext): T

    Permalink
  80. abstract def visitLogicalBinary(ctx: LogicalBinaryContext): T

    Permalink
  81. abstract def visitLogicalNot(ctx: LogicalNotContext): T

    Permalink
  82. abstract def visitManageResource(ctx: ManageResourceContext): T

    Permalink
  83. abstract def visitMultiInsertQuery(ctx: MultiInsertQueryContext): T

    Permalink
  84. abstract def visitMultiInsertQueryBody(ctx: MultiInsertQueryBodyContext): T

    Permalink
  85. abstract def visitNamedExpression(ctx: NamedExpressionContext): T

    Permalink
  86. abstract def visitNamedExpressionSeq(ctx: NamedExpressionSeqContext): T

    Permalink
  87. abstract def visitNamedQuery(ctx: NamedQueryContext): T

    Permalink
  88. abstract def visitNamedWindow(ctx: NamedWindowContext): T

    Permalink
  89. abstract def visitNestedConstantList(ctx: NestedConstantListContext): T

    Permalink
  90. abstract def visitNonReserved(ctx: NonReservedContext): T

    Permalink
  91. abstract def visitNullLiteral(ctx: NullLiteralContext): T

    Permalink
  92. abstract def visitNumericLiteral(ctx: NumericLiteralContext): T

    Permalink
  93. abstract def visitOrderedIdentifier(ctx: OrderedIdentifierContext): T

    Permalink
  94. abstract def visitOrderedIdentifierList(ctx: OrderedIdentifierListContext): T

    Permalink
  95. abstract def visitParenthesizedExpression(ctx: ParenthesizedExpressionContext): T

    Permalink
  96. abstract def visitPartitionSpec(ctx: PartitionSpecContext): T

    Permalink
  97. abstract def visitPartitionSpecLocation(ctx: PartitionSpecLocationContext): T

    Permalink
  98. abstract def visitPartitionVal(ctx: PartitionValContext): T

    Permalink
  99. abstract def visitPredicate(ctx: PredicateContext): T

    Permalink
  100. abstract def visitPredicateOperator(ctx: PredicateOperatorContext): T

    Permalink
  101. abstract def visitPredicated(ctx: PredicatedContext): T

    Permalink
  102. abstract def visitPrimitiveDataType(ctx: PrimitiveDataTypeContext): T

    Permalink
  103. abstract def visitQualifiedName(ctx: QualifiedNameContext): T

    Permalink
  104. abstract def visitQuery(ctx: QueryContext): T

    Permalink
  105. abstract def visitQueryOrganization(ctx: QueryOrganizationContext): T

    Permalink
  106. abstract def visitQueryPrimaryDefault(ctx: QueryPrimaryDefaultContext): T

    Permalink
  107. abstract def visitQuerySpecification(ctx: QuerySpecificationContext): T

    Permalink
  108. abstract def visitQueryTermDefault(ctx: QueryTermDefaultContext): T

    Permalink
  109. abstract def visitQuotedIdentifier(ctx: QuotedIdentifierContext): T

    Permalink
  110. abstract def visitQuotedIdentifierAlternative(ctx: QuotedIdentifierAlternativeContext): T

    Permalink
  111. abstract def visitRefreshResource(ctx: RefreshResourceContext): T

    Permalink
  112. abstract def visitRefreshTable(ctx: RefreshTableContext): T

    Permalink
  113. abstract def visitRelationDefault(ctx: RelationDefaultContext): T

    Permalink
  114. abstract def visitRenameTable(ctx: RenameTableContext): T

    Permalink
  115. abstract def visitRenameTablePartition(ctx: RenameTablePartitionContext): T

    Permalink
  116. abstract def visitResetConfiguration(ctx: ResetConfigurationContext): T

    Permalink
  117. abstract def visitResource(ctx: ResourceContext): T

    Permalink
  118. abstract def visitRowConstructor(ctx: RowConstructorContext): T

    Permalink
  119. abstract def visitRowFormatDelimited(ctx: RowFormatDelimitedContext): T

    Permalink
  120. abstract def visitRowFormatSerde(ctx: RowFormatSerdeContext): T

    Permalink
  121. abstract def visitSample(ctx: SampleContext): T

    Permalink
  122. abstract def visitScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): T

    Permalink
  123. abstract def visitSearchedCase(ctx: SearchedCaseContext): T

    Permalink
  124. abstract def visitSetConfiguration(ctx: SetConfigurationContext): T

    Permalink
  125. abstract def visitSetDatabaseProperties(ctx: SetDatabasePropertiesContext): T

    Permalink
  126. abstract def visitSetOperation(ctx: SetOperationContext): T

    Permalink
  127. abstract def visitSetQuantifier(ctx: SetQuantifierContext): T

    Permalink
  128. abstract def visitSetTableLocation(ctx: SetTableLocationContext): T

    Permalink
  129. abstract def visitSetTableProperties(ctx: SetTablePropertiesContext): T

    Permalink
  130. abstract def visitSetTableSerDe(ctx: SetTableSerDeContext): T

    Permalink
  131. abstract def visitShowColumns(ctx: ShowColumnsContext): T

    Permalink
  132. abstract def visitShowCreateTable(ctx: ShowCreateTableContext): T

    Permalink
  133. abstract def visitShowDatabases(ctx: ShowDatabasesContext): T

    Permalink
  134. abstract def visitShowFunctions(ctx: ShowFunctionsContext): T

    Permalink
  135. abstract def visitShowPartitions(ctx: ShowPartitionsContext): T

    Permalink
  136. abstract def visitShowTables(ctx: ShowTablesContext): T

    Permalink
  137. abstract def visitShowTblProperties(ctx: ShowTblPropertiesContext): T

    Permalink
  138. abstract def visitSimpleCase(ctx: SimpleCaseContext): T

    Permalink
  139. abstract def visitSingleDataType(ctx: SingleDataTypeContext): T

    Permalink
  140. abstract def visitSingleExpression(ctx: SingleExpressionContext): T

    Permalink
  141. abstract def visitSingleInsertQuery(ctx: SingleInsertQueryContext): T

    Permalink
  142. abstract def visitSingleStatement(ctx: SingleStatementContext): T

    Permalink
  143. abstract def visitSingleTableIdentifier(ctx: SingleTableIdentifierContext): T

    Permalink
  144. abstract def visitSkewSpec(ctx: SkewSpecContext): T

    Permalink
  145. abstract def visitSmallIntLiteral(ctx: SmallIntLiteralContext): T

    Permalink
  146. abstract def visitSortItem(ctx: SortItemContext): T

    Permalink
  147. abstract def visitStar(ctx: StarContext): T

    Permalink
  148. abstract def visitStatementDefault(ctx: StatementDefaultContext): T

    Permalink
  149. abstract def visitStorageHandler(ctx: StorageHandlerContext): T

    Permalink
  150. abstract def visitStringLiteral(ctx: StringLiteralContext): T

    Permalink
  151. abstract def visitSubquery(ctx: SubqueryContext): T

    Permalink
  152. abstract def visitSubqueryExpression(ctx: SubqueryExpressionContext): T

    Permalink
  153. abstract def visitSubscript(ctx: SubscriptContext): T

    Permalink
  154. abstract def visitTable(ctx: TableContext): T

    Permalink
  155. abstract def visitTableFileFormat(ctx: TableFileFormatContext): T

    Permalink
  156. abstract def visitTableIdentifier(ctx: TableIdentifierContext): T

    Permalink
  157. abstract def visitTableName(ctx: TableNameContext): T

    Permalink
  158. abstract def visitTableProperty(ctx: TablePropertyContext): T

    Permalink
  159. abstract def visitTablePropertyKey(ctx: TablePropertyKeyContext): T

    Permalink
  160. abstract def visitTablePropertyList(ctx: TablePropertyListContext): T

    Permalink
  161. abstract def visitTableProvider(ctx: TableProviderContext): T

    Permalink
  162. abstract def visitTerminal(arg0: TerminalNode): T

    Permalink
    Definition Classes
    ParseTreeVisitor
  163. abstract def visitTinyIntLiteral(ctx: TinyIntLiteralContext): T

    Permalink
  164. abstract def visitTruncateTable(ctx: TruncateTableContext): T

    Permalink
  165. abstract def visitTypeConstructor(ctx: TypeConstructorContext): T

    Permalink
  166. abstract def visitUncacheTable(ctx: UncacheTableContext): T

    Permalink
  167. abstract def visitUnquotedIdentifier(ctx: UnquotedIdentifierContext): T

    Permalink
  168. abstract def visitUnsetTableProperties(ctx: UnsetTablePropertiesContext): T

    Permalink
  169. abstract def visitUnsupportedHiveNativeCommands(ctx: UnsupportedHiveNativeCommandsContext): T

    Permalink
  170. abstract def visitUse(ctx: UseContext): T

    Permalink
  171. abstract def visitValueExpressionDefault(ctx: ValueExpressionDefaultContext): T

    Permalink
  172. abstract def visitWhenClause(ctx: WhenClauseContext): T

    Permalink
  173. abstract def visitWindowDef(ctx: WindowDefContext): T

    Permalink
  174. abstract def visitWindowFrame(ctx: WindowFrameContext): T

    Permalink
  175. abstract def visitWindowRef(ctx: WindowRefContext): T

    Permalink
  176. abstract def visitWindows(ctx: WindowsContext): T

    Permalink

Concrete 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. final def asInstanceOf[T0]: T0

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  8. def finalize(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  11. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  12. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  15. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  17. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ParseTreeVisitor[T]

Inherited from AnyRef

Inherited from Any

Ungrouped