org.apache.spark.sql.catalyst.parser

SqlBaseListener

trait SqlBaseListener extends ParseTreeListener

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

Abstract Value Members

  1. abstract def enterAddTablePartition(ctx: AddTablePartitionContext): Unit

  2. abstract def enterAggregation(ctx: AggregationContext): Unit

  3. abstract def enterAliasedQuery(ctx: AliasedQueryContext): Unit

  4. abstract def enterAliasedRelation(ctx: AliasedRelationContext): Unit

  5. abstract def enterAlterViewQuery(ctx: AlterViewQueryContext): Unit

  6. abstract def enterAnalyze(ctx: AnalyzeContext): Unit

  7. abstract def enterArithmeticBinary(ctx: ArithmeticBinaryContext): Unit

  8. abstract def enterArithmeticOperator(ctx: ArithmeticOperatorContext): Unit

  9. abstract def enterArithmeticUnary(ctx: ArithmeticUnaryContext): Unit

  10. abstract def enterBigIntLiteral(ctx: BigIntLiteralContext): Unit

  11. abstract def enterBooleanDefault(ctx: BooleanDefaultContext): Unit

  12. abstract def enterBooleanLiteral(ctx: BooleanLiteralContext): Unit

  13. abstract def enterBooleanValue(ctx: BooleanValueContext): Unit

  14. abstract def enterBucketSpec(ctx: BucketSpecContext): Unit

  15. abstract def enterCacheTable(ctx: CacheTableContext): Unit

  16. abstract def enterCast(ctx: CastContext): Unit

  17. abstract def enterClearCache(ctx: ClearCacheContext): Unit

  18. abstract def enterColType(ctx: ColTypeContext): Unit

  19. abstract def enterColTypeList(ctx: ColTypeListContext): Unit

  20. abstract def enterColumnReference(ctx: ColumnReferenceContext): Unit

  21. abstract def enterComparison(ctx: ComparisonContext): Unit

  22. abstract def enterComparisonOperator(ctx: ComparisonOperatorContext): Unit

  23. abstract def enterComplexDataType(ctx: ComplexDataTypeContext): Unit

  24. abstract def enterConstantDefault(ctx: ConstantDefaultContext): Unit

  25. abstract def enterConstantList(ctx: ConstantListContext): Unit

  26. abstract def enterCreateDatabase(ctx: CreateDatabaseContext): Unit

  27. abstract def enterCreateFileFormat(ctx: CreateFileFormatContext): Unit

  28. abstract def enterCreateFunction(ctx: CreateFunctionContext): Unit

  29. abstract def enterCreateTable(ctx: CreateTableContext): Unit

  30. abstract def enterCreateTableHeader(ctx: CreateTableHeaderContext): Unit

  31. abstract def enterCreateTableLike(ctx: CreateTableLikeContext): Unit

  32. abstract def enterCreateTableUsing(ctx: CreateTableUsingContext): Unit

  33. abstract def enterCreateTempViewUsing(ctx: CreateTempViewUsingContext): Unit

  34. abstract def enterCreateView(ctx: CreateViewContext): Unit

  35. abstract def enterCtes(ctx: CtesContext): Unit

  36. abstract def enterDecimalLiteral(ctx: DecimalLiteralContext): Unit

  37. abstract def enterDereference(ctx: DereferenceContext): Unit

  38. abstract def enterDescribeColName(ctx: DescribeColNameContext): Unit

  39. abstract def enterDescribeDatabase(ctx: DescribeDatabaseContext): Unit

  40. abstract def enterDescribeFuncName(ctx: DescribeFuncNameContext): Unit

  41. abstract def enterDescribeFunction(ctx: DescribeFunctionContext): Unit

  42. abstract def enterDescribeTable(ctx: DescribeTableContext): Unit

  43. abstract def enterDoubleLiteral(ctx: DoubleLiteralContext): Unit

  44. abstract def enterDropDatabase(ctx: DropDatabaseContext): Unit

  45. abstract def enterDropFunction(ctx: DropFunctionContext): Unit

  46. abstract def enterDropTable(ctx: DropTableContext): Unit

  47. abstract def enterDropTablePartitions(ctx: DropTablePartitionsContext): Unit

  48. abstract def enterEveryRule(arg0: ParserRuleContext): Unit

    Definition Classes
    ParseTreeListener
  49. abstract def enterExists(ctx: ExistsContext): Unit

  50. abstract def enterExplain(ctx: ExplainContext): Unit

  51. abstract def enterExpression(ctx: ExpressionContext): Unit

  52. abstract def enterFailNativeCommand(ctx: FailNativeCommandContext): Unit

  53. abstract def enterFrameBound(ctx: FrameBoundContext): Unit

  54. abstract def enterFromClause(ctx: FromClauseContext): Unit

  55. abstract def enterFunctionCall(ctx: FunctionCallContext): Unit

  56. abstract def enterGenericFileFormat(ctx: GenericFileFormatContext): Unit

  57. abstract def enterGroupingSet(ctx: GroupingSetContext): Unit

  58. abstract def enterIdentifier(ctx: IdentifierContext): Unit

  59. abstract def enterIdentifierComment(ctx: IdentifierCommentContext): Unit

  60. abstract def enterIdentifierCommentList(ctx: IdentifierCommentListContext): Unit

  61. abstract def enterIdentifierList(ctx: IdentifierListContext): Unit

  62. abstract def enterIdentifierSeq(ctx: IdentifierSeqContext): Unit

  63. abstract def enterInlineTable(ctx: InlineTableContext): Unit

  64. abstract def enterInlineTableDefault1(ctx: InlineTableDefault1Context): Unit

  65. abstract def enterInlineTableDefault2(ctx: InlineTableDefault2Context): Unit

  66. abstract def enterInsertInto(ctx: InsertIntoContext): Unit

  67. abstract def enterIntegerLiteral(ctx: IntegerLiteralContext): Unit

  68. abstract def enterInterval(ctx: IntervalContext): Unit

  69. abstract def enterIntervalField(ctx: IntervalFieldContext): Unit

  70. abstract def enterIntervalLiteral(ctx: IntervalLiteralContext): Unit

  71. abstract def enterIntervalValue(ctx: IntervalValueContext): Unit

  72. abstract def enterJoinCriteria(ctx: JoinCriteriaContext): Unit

  73. abstract def enterJoinRelation(ctx: JoinRelationContext): Unit

  74. abstract def enterJoinType(ctx: JoinTypeContext): Unit

  75. abstract def enterLateralView(ctx: LateralViewContext): Unit

  76. abstract def enterLoadData(ctx: LoadDataContext): Unit

  77. abstract def enterLocationSpec(ctx: LocationSpecContext): Unit

  78. abstract def enterLogicalBinary(ctx: LogicalBinaryContext): Unit

  79. abstract def enterLogicalNot(ctx: LogicalNotContext): Unit

  80. abstract def enterManageResource(ctx: ManageResourceContext): Unit

  81. abstract def enterMultiInsertQuery(ctx: MultiInsertQueryContext): Unit

  82. abstract def enterMultiInsertQueryBody(ctx: MultiInsertQueryBodyContext): Unit

  83. abstract def enterNamedExpression(ctx: NamedExpressionContext): Unit

  84. abstract def enterNamedExpressionSeq(ctx: NamedExpressionSeqContext): Unit

  85. abstract def enterNamedQuery(ctx: NamedQueryContext): Unit

  86. abstract def enterNamedWindow(ctx: NamedWindowContext): Unit

  87. abstract def enterNestedConstantList(ctx: NestedConstantListContext): Unit

  88. abstract def enterNonReserved(ctx: NonReservedContext): Unit

  89. abstract def enterNullLiteral(ctx: NullLiteralContext): Unit

  90. abstract def enterNumericLiteral(ctx: NumericLiteralContext): Unit

  91. abstract def enterOrderedIdentifier(ctx: OrderedIdentifierContext): Unit

  92. abstract def enterOrderedIdentifierList(ctx: OrderedIdentifierListContext): Unit

  93. abstract def enterParenthesizedExpression(ctx: ParenthesizedExpressionContext): Unit

  94. abstract def enterPartitionSpec(ctx: PartitionSpecContext): Unit

  95. abstract def enterPartitionSpecLocation(ctx: PartitionSpecLocationContext): Unit

  96. abstract def enterPartitionVal(ctx: PartitionValContext): Unit

  97. abstract def enterPredicate(ctx: PredicateContext): Unit

  98. abstract def enterPredicateOperator(ctx: PredicateOperatorContext): Unit

  99. abstract def enterPredicated(ctx: PredicatedContext): Unit

  100. abstract def enterPrimitiveDataType(ctx: PrimitiveDataTypeContext): Unit

  101. abstract def enterQualifiedName(ctx: QualifiedNameContext): Unit

  102. abstract def enterQuery(ctx: QueryContext): Unit

  103. abstract def enterQueryOrganization(ctx: QueryOrganizationContext): Unit

  104. abstract def enterQueryPrimaryDefault(ctx: QueryPrimaryDefaultContext): Unit

  105. abstract def enterQuerySpecification(ctx: QuerySpecificationContext): Unit

  106. abstract def enterQueryTermDefault(ctx: QueryTermDefaultContext): Unit

  107. abstract def enterQuotedIdentifier(ctx: QuotedIdentifierContext): Unit

  108. abstract def enterQuotedIdentifierAlternative(ctx: QuotedIdentifierAlternativeContext): Unit

  109. abstract def enterRefreshResource(ctx: RefreshResourceContext): Unit

  110. abstract def enterRefreshTable(ctx: RefreshTableContext): Unit

  111. abstract def enterRelationDefault(ctx: RelationDefaultContext): Unit

  112. abstract def enterRenameTable(ctx: RenameTableContext): Unit

  113. abstract def enterRenameTablePartition(ctx: RenameTablePartitionContext): Unit

  114. abstract def enterResetConfiguration(ctx: ResetConfigurationContext): Unit

  115. abstract def enterResource(ctx: ResourceContext): Unit

  116. abstract def enterRowConstructor(ctx: RowConstructorContext): Unit

  117. abstract def enterRowFormatDelimited(ctx: RowFormatDelimitedContext): Unit

  118. abstract def enterRowFormatSerde(ctx: RowFormatSerdeContext): Unit

  119. abstract def enterSample(ctx: SampleContext): Unit

  120. abstract def enterScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): Unit

  121. abstract def enterSearchedCase(ctx: SearchedCaseContext): Unit

  122. abstract def enterSetConfiguration(ctx: SetConfigurationContext): Unit

  123. abstract def enterSetDatabaseProperties(ctx: SetDatabasePropertiesContext): Unit

  124. abstract def enterSetOperation(ctx: SetOperationContext): Unit

  125. abstract def enterSetQuantifier(ctx: SetQuantifierContext): Unit

  126. abstract def enterSetTableLocation(ctx: SetTableLocationContext): Unit

  127. abstract def enterSetTableProperties(ctx: SetTablePropertiesContext): Unit

  128. abstract def enterSetTableSerDe(ctx: SetTableSerDeContext): Unit

  129. abstract def enterShowColumns(ctx: ShowColumnsContext): Unit

  130. abstract def enterShowCreateTable(ctx: ShowCreateTableContext): Unit

  131. abstract def enterShowDatabases(ctx: ShowDatabasesContext): Unit

  132. abstract def enterShowFunctions(ctx: ShowFunctionsContext): Unit

  133. abstract def enterShowPartitions(ctx: ShowPartitionsContext): Unit

  134. abstract def enterShowTables(ctx: ShowTablesContext): Unit

  135. abstract def enterShowTblProperties(ctx: ShowTblPropertiesContext): Unit

  136. abstract def enterSimpleCase(ctx: SimpleCaseContext): Unit

  137. abstract def enterSingleDataType(ctx: SingleDataTypeContext): Unit

  138. abstract def enterSingleExpression(ctx: SingleExpressionContext): Unit

  139. abstract def enterSingleInsertQuery(ctx: SingleInsertQueryContext): Unit

  140. abstract def enterSingleStatement(ctx: SingleStatementContext): Unit

  141. abstract def enterSingleTableIdentifier(ctx: SingleTableIdentifierContext): Unit

  142. abstract def enterSkewSpec(ctx: SkewSpecContext): Unit

  143. abstract def enterSmallIntLiteral(ctx: SmallIntLiteralContext): Unit

  144. abstract def enterSortItem(ctx: SortItemContext): Unit

  145. abstract def enterStar(ctx: StarContext): Unit

  146. abstract def enterStatementDefault(ctx: StatementDefaultContext): Unit

  147. abstract def enterStorageHandler(ctx: StorageHandlerContext): Unit

  148. abstract def enterStringLiteral(ctx: StringLiteralContext): Unit

  149. abstract def enterSubquery(ctx: SubqueryContext): Unit

  150. abstract def enterSubqueryExpression(ctx: SubqueryExpressionContext): Unit

  151. abstract def enterSubscript(ctx: SubscriptContext): Unit

  152. abstract def enterTable(ctx: TableContext): Unit

  153. abstract def enterTableFileFormat(ctx: TableFileFormatContext): Unit

  154. abstract def enterTableIdentifier(ctx: TableIdentifierContext): Unit

  155. abstract def enterTableName(ctx: TableNameContext): Unit

  156. abstract def enterTableProperty(ctx: TablePropertyContext): Unit

  157. abstract def enterTablePropertyKey(ctx: TablePropertyKeyContext): Unit

  158. abstract def enterTablePropertyList(ctx: TablePropertyListContext): Unit

  159. abstract def enterTableProvider(ctx: TableProviderContext): Unit

  160. abstract def enterTinyIntLiteral(ctx: TinyIntLiteralContext): Unit

  161. abstract def enterTruncateTable(ctx: TruncateTableContext): Unit

  162. abstract def enterTypeConstructor(ctx: TypeConstructorContext): Unit

  163. abstract def enterUncacheTable(ctx: UncacheTableContext): Unit

  164. abstract def enterUnquotedIdentifier(ctx: UnquotedIdentifierContext): Unit

  165. abstract def enterUnsetTableProperties(ctx: UnsetTablePropertiesContext): Unit

  166. abstract def enterUnsupportedHiveNativeCommands(ctx: UnsupportedHiveNativeCommandsContext): Unit

  167. abstract def enterUse(ctx: UseContext): Unit

  168. abstract def enterValueExpressionDefault(ctx: ValueExpressionDefaultContext): Unit

  169. abstract def enterWhenClause(ctx: WhenClauseContext): Unit

  170. abstract def enterWindowDef(ctx: WindowDefContext): Unit

  171. abstract def enterWindowFrame(ctx: WindowFrameContext): Unit

  172. abstract def enterWindowRef(ctx: WindowRefContext): Unit

  173. abstract def enterWindows(ctx: WindowsContext): Unit

  174. abstract def exitAddTablePartition(ctx: AddTablePartitionContext): Unit

  175. abstract def exitAggregation(ctx: AggregationContext): Unit

  176. abstract def exitAliasedQuery(ctx: AliasedQueryContext): Unit

  177. abstract def exitAliasedRelation(ctx: AliasedRelationContext): Unit

  178. abstract def exitAlterViewQuery(ctx: AlterViewQueryContext): Unit

  179. abstract def exitAnalyze(ctx: AnalyzeContext): Unit

  180. abstract def exitArithmeticBinary(ctx: ArithmeticBinaryContext): Unit

  181. abstract def exitArithmeticOperator(ctx: ArithmeticOperatorContext): Unit

  182. abstract def exitArithmeticUnary(ctx: ArithmeticUnaryContext): Unit

  183. abstract def exitBigIntLiteral(ctx: BigIntLiteralContext): Unit

  184. abstract def exitBooleanDefault(ctx: BooleanDefaultContext): Unit

  185. abstract def exitBooleanLiteral(ctx: BooleanLiteralContext): Unit

  186. abstract def exitBooleanValue(ctx: BooleanValueContext): Unit

  187. abstract def exitBucketSpec(ctx: BucketSpecContext): Unit

  188. abstract def exitCacheTable(ctx: CacheTableContext): Unit

  189. abstract def exitCast(ctx: CastContext): Unit

  190. abstract def exitClearCache(ctx: ClearCacheContext): Unit

  191. abstract def exitColType(ctx: ColTypeContext): Unit

  192. abstract def exitColTypeList(ctx: ColTypeListContext): Unit

  193. abstract def exitColumnReference(ctx: ColumnReferenceContext): Unit

  194. abstract def exitComparison(ctx: ComparisonContext): Unit

  195. abstract def exitComparisonOperator(ctx: ComparisonOperatorContext): Unit

  196. abstract def exitComplexDataType(ctx: ComplexDataTypeContext): Unit

  197. abstract def exitConstantDefault(ctx: ConstantDefaultContext): Unit

  198. abstract def exitConstantList(ctx: ConstantListContext): Unit

  199. abstract def exitCreateDatabase(ctx: CreateDatabaseContext): Unit

  200. abstract def exitCreateFileFormat(ctx: CreateFileFormatContext): Unit

  201. abstract def exitCreateFunction(ctx: CreateFunctionContext): Unit

  202. abstract def exitCreateTable(ctx: CreateTableContext): Unit

  203. abstract def exitCreateTableHeader(ctx: CreateTableHeaderContext): Unit

  204. abstract def exitCreateTableLike(ctx: CreateTableLikeContext): Unit

  205. abstract def exitCreateTableUsing(ctx: CreateTableUsingContext): Unit

  206. abstract def exitCreateTempViewUsing(ctx: CreateTempViewUsingContext): Unit

  207. abstract def exitCreateView(ctx: CreateViewContext): Unit

  208. abstract def exitCtes(ctx: CtesContext): Unit

  209. abstract def exitDecimalLiteral(ctx: DecimalLiteralContext): Unit

  210. abstract def exitDereference(ctx: DereferenceContext): Unit

  211. abstract def exitDescribeColName(ctx: DescribeColNameContext): Unit

  212. abstract def exitDescribeDatabase(ctx: DescribeDatabaseContext): Unit

  213. abstract def exitDescribeFuncName(ctx: DescribeFuncNameContext): Unit

  214. abstract def exitDescribeFunction(ctx: DescribeFunctionContext): Unit

  215. abstract def exitDescribeTable(ctx: DescribeTableContext): Unit

  216. abstract def exitDoubleLiteral(ctx: DoubleLiteralContext): Unit

  217. abstract def exitDropDatabase(ctx: DropDatabaseContext): Unit

  218. abstract def exitDropFunction(ctx: DropFunctionContext): Unit

  219. abstract def exitDropTable(ctx: DropTableContext): Unit

  220. abstract def exitDropTablePartitions(ctx: DropTablePartitionsContext): Unit

  221. abstract def exitEveryRule(arg0: ParserRuleContext): Unit

    Definition Classes
    ParseTreeListener
  222. abstract def exitExists(ctx: ExistsContext): Unit

  223. abstract def exitExplain(ctx: ExplainContext): Unit

  224. abstract def exitExpression(ctx: ExpressionContext): Unit

  225. abstract def exitFailNativeCommand(ctx: FailNativeCommandContext): Unit

  226. abstract def exitFrameBound(ctx: FrameBoundContext): Unit

  227. abstract def exitFromClause(ctx: FromClauseContext): Unit

  228. abstract def exitFunctionCall(ctx: FunctionCallContext): Unit

  229. abstract def exitGenericFileFormat(ctx: GenericFileFormatContext): Unit

  230. abstract def exitGroupingSet(ctx: GroupingSetContext): Unit

  231. abstract def exitIdentifier(ctx: IdentifierContext): Unit

  232. abstract def exitIdentifierComment(ctx: IdentifierCommentContext): Unit

  233. abstract def exitIdentifierCommentList(ctx: IdentifierCommentListContext): Unit

  234. abstract def exitIdentifierList(ctx: IdentifierListContext): Unit

  235. abstract def exitIdentifierSeq(ctx: IdentifierSeqContext): Unit

  236. abstract def exitInlineTable(ctx: InlineTableContext): Unit

  237. abstract def exitInlineTableDefault1(ctx: InlineTableDefault1Context): Unit

  238. abstract def exitInlineTableDefault2(ctx: InlineTableDefault2Context): Unit

  239. abstract def exitInsertInto(ctx: InsertIntoContext): Unit

  240. abstract def exitIntegerLiteral(ctx: IntegerLiteralContext): Unit

  241. abstract def exitInterval(ctx: IntervalContext): Unit

  242. abstract def exitIntervalField(ctx: IntervalFieldContext): Unit

  243. abstract def exitIntervalLiteral(ctx: IntervalLiteralContext): Unit

  244. abstract def exitIntervalValue(ctx: IntervalValueContext): Unit

  245. abstract def exitJoinCriteria(ctx: JoinCriteriaContext): Unit

  246. abstract def exitJoinRelation(ctx: JoinRelationContext): Unit

  247. abstract def exitJoinType(ctx: JoinTypeContext): Unit

  248. abstract def exitLateralView(ctx: LateralViewContext): Unit

  249. abstract def exitLoadData(ctx: LoadDataContext): Unit

  250. abstract def exitLocationSpec(ctx: LocationSpecContext): Unit

  251. abstract def exitLogicalBinary(ctx: LogicalBinaryContext): Unit

  252. abstract def exitLogicalNot(ctx: LogicalNotContext): Unit

  253. abstract def exitManageResource(ctx: ManageResourceContext): Unit

  254. abstract def exitMultiInsertQuery(ctx: MultiInsertQueryContext): Unit

  255. abstract def exitMultiInsertQueryBody(ctx: MultiInsertQueryBodyContext): Unit

  256. abstract def exitNamedExpression(ctx: NamedExpressionContext): Unit

  257. abstract def exitNamedExpressionSeq(ctx: NamedExpressionSeqContext): Unit

  258. abstract def exitNamedQuery(ctx: NamedQueryContext): Unit

  259. abstract def exitNamedWindow(ctx: NamedWindowContext): Unit

  260. abstract def exitNestedConstantList(ctx: NestedConstantListContext): Unit

  261. abstract def exitNonReserved(ctx: NonReservedContext): Unit

  262. abstract def exitNullLiteral(ctx: NullLiteralContext): Unit

  263. abstract def exitNumericLiteral(ctx: NumericLiteralContext): Unit

  264. abstract def exitOrderedIdentifier(ctx: OrderedIdentifierContext): Unit

  265. abstract def exitOrderedIdentifierList(ctx: OrderedIdentifierListContext): Unit

  266. abstract def exitParenthesizedExpression(ctx: ParenthesizedExpressionContext): Unit

  267. abstract def exitPartitionSpec(ctx: PartitionSpecContext): Unit

  268. abstract def exitPartitionSpecLocation(ctx: PartitionSpecLocationContext): Unit

  269. abstract def exitPartitionVal(ctx: PartitionValContext): Unit

  270. abstract def exitPredicate(ctx: PredicateContext): Unit

  271. abstract def exitPredicateOperator(ctx: PredicateOperatorContext): Unit

  272. abstract def exitPredicated(ctx: PredicatedContext): Unit

  273. abstract def exitPrimitiveDataType(ctx: PrimitiveDataTypeContext): Unit

  274. abstract def exitQualifiedName(ctx: QualifiedNameContext): Unit

  275. abstract def exitQuery(ctx: QueryContext): Unit

  276. abstract def exitQueryOrganization(ctx: QueryOrganizationContext): Unit

  277. abstract def exitQueryPrimaryDefault(ctx: QueryPrimaryDefaultContext): Unit

  278. abstract def exitQuerySpecification(ctx: QuerySpecificationContext): Unit

  279. abstract def exitQueryTermDefault(ctx: QueryTermDefaultContext): Unit

  280. abstract def exitQuotedIdentifier(ctx: QuotedIdentifierContext): Unit

  281. abstract def exitQuotedIdentifierAlternative(ctx: QuotedIdentifierAlternativeContext): Unit

  282. abstract def exitRefreshResource(ctx: RefreshResourceContext): Unit

  283. abstract def exitRefreshTable(ctx: RefreshTableContext): Unit

  284. abstract def exitRelationDefault(ctx: RelationDefaultContext): Unit

  285. abstract def exitRenameTable(ctx: RenameTableContext): Unit

  286. abstract def exitRenameTablePartition(ctx: RenameTablePartitionContext): Unit

  287. abstract def exitResetConfiguration(ctx: ResetConfigurationContext): Unit

  288. abstract def exitResource(ctx: ResourceContext): Unit

  289. abstract def exitRowConstructor(ctx: RowConstructorContext): Unit

  290. abstract def exitRowFormatDelimited(ctx: RowFormatDelimitedContext): Unit

  291. abstract def exitRowFormatSerde(ctx: RowFormatSerdeContext): Unit

  292. abstract def exitSample(ctx: SampleContext): Unit

  293. abstract def exitScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): Unit

  294. abstract def exitSearchedCase(ctx: SearchedCaseContext): Unit

  295. abstract def exitSetConfiguration(ctx: SetConfigurationContext): Unit

  296. abstract def exitSetDatabaseProperties(ctx: SetDatabasePropertiesContext): Unit

  297. abstract def exitSetOperation(ctx: SetOperationContext): Unit

  298. abstract def exitSetQuantifier(ctx: SetQuantifierContext): Unit

  299. abstract def exitSetTableLocation(ctx: SetTableLocationContext): Unit

  300. abstract def exitSetTableProperties(ctx: SetTablePropertiesContext): Unit

  301. abstract def exitSetTableSerDe(ctx: SetTableSerDeContext): Unit

  302. abstract def exitShowColumns(ctx: ShowColumnsContext): Unit

  303. abstract def exitShowCreateTable(ctx: ShowCreateTableContext): Unit

  304. abstract def exitShowDatabases(ctx: ShowDatabasesContext): Unit

  305. abstract def exitShowFunctions(ctx: ShowFunctionsContext): Unit

  306. abstract def exitShowPartitions(ctx: ShowPartitionsContext): Unit

  307. abstract def exitShowTables(ctx: ShowTablesContext): Unit

  308. abstract def exitShowTblProperties(ctx: ShowTblPropertiesContext): Unit

  309. abstract def exitSimpleCase(ctx: SimpleCaseContext): Unit

  310. abstract def exitSingleDataType(ctx: SingleDataTypeContext): Unit

  311. abstract def exitSingleExpression(ctx: SingleExpressionContext): Unit

  312. abstract def exitSingleInsertQuery(ctx: SingleInsertQueryContext): Unit

  313. abstract def exitSingleStatement(ctx: SingleStatementContext): Unit

  314. abstract def exitSingleTableIdentifier(ctx: SingleTableIdentifierContext): Unit

  315. abstract def exitSkewSpec(ctx: SkewSpecContext): Unit

  316. abstract def exitSmallIntLiteral(ctx: SmallIntLiteralContext): Unit

  317. abstract def exitSortItem(ctx: SortItemContext): Unit

  318. abstract def exitStar(ctx: StarContext): Unit

  319. abstract def exitStatementDefault(ctx: StatementDefaultContext): Unit

  320. abstract def exitStorageHandler(ctx: StorageHandlerContext): Unit

  321. abstract def exitStringLiteral(ctx: StringLiteralContext): Unit

  322. abstract def exitSubquery(ctx: SubqueryContext): Unit

  323. abstract def exitSubqueryExpression(ctx: SubqueryExpressionContext): Unit

  324. abstract def exitSubscript(ctx: SubscriptContext): Unit

  325. abstract def exitTable(ctx: TableContext): Unit

  326. abstract def exitTableFileFormat(ctx: TableFileFormatContext): Unit

  327. abstract def exitTableIdentifier(ctx: TableIdentifierContext): Unit

  328. abstract def exitTableName(ctx: TableNameContext): Unit

  329. abstract def exitTableProperty(ctx: TablePropertyContext): Unit

  330. abstract def exitTablePropertyKey(ctx: TablePropertyKeyContext): Unit

  331. abstract def exitTablePropertyList(ctx: TablePropertyListContext): Unit

  332. abstract def exitTableProvider(ctx: TableProviderContext): Unit

  333. abstract def exitTinyIntLiteral(ctx: TinyIntLiteralContext): Unit

  334. abstract def exitTruncateTable(ctx: TruncateTableContext): Unit

  335. abstract def exitTypeConstructor(ctx: TypeConstructorContext): Unit

  336. abstract def exitUncacheTable(ctx: UncacheTableContext): Unit

  337. abstract def exitUnquotedIdentifier(ctx: UnquotedIdentifierContext): Unit

  338. abstract def exitUnsetTableProperties(ctx: UnsetTablePropertiesContext): Unit

  339. abstract def exitUnsupportedHiveNativeCommands(ctx: UnsupportedHiveNativeCommandsContext): Unit

  340. abstract def exitUse(ctx: UseContext): Unit

  341. abstract def exitValueExpressionDefault(ctx: ValueExpressionDefaultContext): Unit

  342. abstract def exitWhenClause(ctx: WhenClauseContext): Unit

  343. abstract def exitWindowDef(ctx: WindowDefContext): Unit

  344. abstract def exitWindowFrame(ctx: WindowFrameContext): Unit

  345. abstract def exitWindowRef(ctx: WindowRefContext): Unit

  346. abstract def exitWindows(ctx: WindowsContext): Unit

  347. abstract def visitErrorNode(arg0: ErrorNode): Unit

    Definition Classes
    ParseTreeListener
  348. abstract def visitTerminal(arg0: TerminalNode): Unit

    Definition Classes
    ParseTreeListener

Concrete Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

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

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def clone(): AnyRef

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

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

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

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

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

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

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

    Definition Classes
    AnyRef
  15. final def notify(): Unit

    Definition Classes
    AnyRef
  16. final def notifyAll(): Unit

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

    Definition Classes
    AnyRef
  18. def toString(): String

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ParseTreeListener

Inherited from AnyRef

Inherited from Any

Ungrouped