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 enterBigDecimalLiteral(ctx: BigDecimalLiteralContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

  24. abstract def enterComplexColType(ctx: ComplexColTypeContext): Unit

  25. abstract def enterComplexColTypeList(ctx: ComplexColTypeListContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

  112. abstract def enterRecoverPartitions(ctx: RecoverPartitionsContext): Unit

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

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

  115. abstract def enterRelation(ctx: RelationContext): Unit

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

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

  118. abstract def enterRepairTable(ctx: RepairTableContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

  163. abstract def enterTablePropertyValue(ctx: TablePropertyValueContext): Unit

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

  165. abstract def enterTableValuedFunction(ctx: TableValuedFunctionContext): Unit

  166. abstract def enterTimeFunctionCall(ctx: TimeFunctionCallContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

  190. abstract def exitBigDecimalLiteral(ctx: BigDecimalLiteralContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

  204. abstract def exitComplexColType(ctx: ComplexColTypeContext): Unit

  205. abstract def exitComplexColTypeList(ctx: ComplexColTypeListContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

  292. abstract def exitRecoverPartitions(ctx: RecoverPartitionsContext): Unit

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

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

  295. abstract def exitRelation(ctx: RelationContext): Unit

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

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

  298. abstract def exitRepairTable(ctx: RepairTableContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

  343. abstract def exitTablePropertyValue(ctx: TablePropertyValueContext): Unit

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

  345. abstract def exitTableValuedFunction(ctx: TableValuedFunctionContext): Unit

  346. abstract def exitTimeFunctionCall(ctx: TimeFunctionCallContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Definition Classes
    ParseTreeListener
  362. 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