Trait

org.apache.spark.sql.catalyst.parser

SqlBaseListener

Related Doc: package parser

Permalink

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
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract def enterAddResource(ctx: AddResourceContext): Unit

    Permalink
  2. abstract def enterAddTablePartition(ctx: AddTablePartitionContext): Unit

    Permalink
  3. abstract def enterAggregation(ctx: AggregationContext): Unit

    Permalink
  4. abstract def enterAliasedQuery(ctx: AliasedQueryContext): Unit

    Permalink
  5. abstract def enterAliasedRelation(ctx: AliasedRelationContext): Unit

    Permalink
  6. abstract def enterAlterViewQuery(ctx: AlterViewQueryContext): Unit

    Permalink
  7. abstract def enterAnalyze(ctx: AnalyzeContext): Unit

    Permalink
  8. abstract def enterArithmeticBinary(ctx: ArithmeticBinaryContext): Unit

    Permalink
  9. abstract def enterArithmeticOperator(ctx: ArithmeticOperatorContext): Unit

    Permalink
  10. abstract def enterArithmeticUnary(ctx: ArithmeticUnaryContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
  24. abstract def enterComplexDataType(ctx: ComplexDataTypeContext): Unit

    Permalink
  25. abstract def enterConstantDefault(ctx: ConstantDefaultContext): Unit

    Permalink
  26. abstract def enterConstantList(ctx: ConstantListContext): Unit

    Permalink
  27. abstract def enterCreateDatabase(ctx: CreateDatabaseContext): Unit

    Permalink
  28. abstract def enterCreateFileFormat(ctx: CreateFileFormatContext): Unit

    Permalink
  29. abstract def enterCreateFunction(ctx: CreateFunctionContext): Unit

    Permalink
  30. abstract def enterCreateTable(ctx: CreateTableContext): Unit

    Permalink
  31. abstract def enterCreateTableHeader(ctx: CreateTableHeaderContext): Unit

    Permalink
  32. abstract def enterCreateTableLike(ctx: CreateTableLikeContext): Unit

    Permalink
  33. abstract def enterCreateTableUsing(ctx: CreateTableUsingContext): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
  58. abstract def enterIdentifierComment(ctx: IdentifierCommentContext): Unit

    Permalink
  59. abstract def enterIdentifierCommentList(ctx: IdentifierCommentListContext): Unit

    Permalink
  60. abstract def enterIdentifierList(ctx: IdentifierListContext): Unit

    Permalink
  61. abstract def enterIdentifierSeq(ctx: IdentifierSeqContext): Unit

    Permalink
  62. abstract def enterInlineTable(ctx: InlineTableContext): Unit

    Permalink
  63. abstract def enterInlineTableDefault1(ctx: InlineTableDefault1Context): Unit

    Permalink
  64. abstract def enterInlineTableDefault2(ctx: InlineTableDefault2Context): Unit

    Permalink
  65. abstract def enterInsertInto(ctx: InsertIntoContext): Unit

    Permalink
  66. abstract def enterIntegerLiteral(ctx: IntegerLiteralContext): Unit

    Permalink
  67. abstract def enterInterval(ctx: IntervalContext): Unit

    Permalink
  68. abstract def enterIntervalField(ctx: IntervalFieldContext): Unit

    Permalink
  69. abstract def enterIntervalLiteral(ctx: IntervalLiteralContext): Unit

    Permalink
  70. abstract def enterIntervalValue(ctx: IntervalValueContext): Unit

    Permalink
  71. abstract def enterJoinCriteria(ctx: JoinCriteriaContext): Unit

    Permalink
  72. abstract def enterJoinRelation(ctx: JoinRelationContext): Unit

    Permalink
  73. abstract def enterJoinType(ctx: JoinTypeContext): Unit

    Permalink
  74. abstract def enterLateralView(ctx: LateralViewContext): Unit

    Permalink
  75. abstract def enterLoadData(ctx: LoadDataContext): Unit

    Permalink
  76. abstract def enterLocationSpec(ctx: LocationSpecContext): Unit

    Permalink
  77. abstract def enterLogicalBinary(ctx: LogicalBinaryContext): Unit

    Permalink
  78. abstract def enterLogicalNot(ctx: LogicalNotContext): Unit

    Permalink
  79. abstract def enterLooseIdentifier(ctx: LooseIdentifierContext): Unit

    Permalink
  80. abstract def enterMultiInsertQuery(ctx: MultiInsertQueryContext): Unit

    Permalink
  81. abstract def enterMultiInsertQueryBody(ctx: MultiInsertQueryBodyContext): Unit

    Permalink
  82. abstract def enterNamedExpression(ctx: NamedExpressionContext): Unit

    Permalink
  83. abstract def enterNamedExpressionSeq(ctx: NamedExpressionSeqContext): Unit

    Permalink
  84. abstract def enterNamedQuery(ctx: NamedQueryContext): Unit

    Permalink
  85. abstract def enterNamedWindow(ctx: NamedWindowContext): Unit

    Permalink
  86. abstract def enterNestedConstantList(ctx: NestedConstantListContext): Unit

    Permalink
  87. abstract def enterNonReserved(ctx: NonReservedContext): Unit

    Permalink
  88. abstract def enterNullLiteral(ctx: NullLiteralContext): Unit

    Permalink
  89. abstract def enterNumericLiteral(ctx: NumericLiteralContext): Unit

    Permalink
  90. abstract def enterOrderedIdentifier(ctx: OrderedIdentifierContext): Unit

    Permalink
  91. abstract def enterOrderedIdentifierList(ctx: OrderedIdentifierListContext): Unit

    Permalink
  92. abstract def enterParenthesizedExpression(ctx: ParenthesizedExpressionContext): Unit

    Permalink
  93. abstract def enterPartitionSpec(ctx: PartitionSpecContext): Unit

    Permalink
  94. abstract def enterPartitionSpecLocation(ctx: PartitionSpecLocationContext): Unit

    Permalink
  95. abstract def enterPartitionVal(ctx: PartitionValContext): Unit

    Permalink
  96. abstract def enterPredicate(ctx: PredicateContext): Unit

    Permalink
  97. abstract def enterPredicateOperator(ctx: PredicateOperatorContext): Unit

    Permalink
  98. abstract def enterPredicated(ctx: PredicatedContext): Unit

    Permalink
  99. abstract def enterPrimitiveDataType(ctx: PrimitiveDataTypeContext): Unit

    Permalink
  100. abstract def enterQualifiedName(ctx: QualifiedNameContext): Unit

    Permalink
  101. abstract def enterQuery(ctx: QueryContext): Unit

    Permalink
  102. abstract def enterQueryOrganization(ctx: QueryOrganizationContext): Unit

    Permalink
  103. abstract def enterQueryPrimaryDefault(ctx: QueryPrimaryDefaultContext): Unit

    Permalink
  104. abstract def enterQuerySpecification(ctx: QuerySpecificationContext): Unit

    Permalink
  105. abstract def enterQueryTermDefault(ctx: QueryTermDefaultContext): Unit

    Permalink
  106. abstract def enterQuotedIdentifier(ctx: QuotedIdentifierContext): Unit

    Permalink
  107. abstract def enterQuotedIdentifierAlternative(ctx: QuotedIdentifierAlternativeContext): Unit

    Permalink
  108. abstract def enterRefreshTable(ctx: RefreshTableContext): Unit

    Permalink
  109. abstract def enterRelationDefault(ctx: RelationDefaultContext): Unit

    Permalink
  110. abstract def enterRenameTable(ctx: RenameTableContext): Unit

    Permalink
  111. abstract def enterRenameTablePartition(ctx: RenameTablePartitionContext): Unit

    Permalink
  112. abstract def enterResource(ctx: ResourceContext): Unit

    Permalink
  113. abstract def enterRowConstructor(ctx: RowConstructorContext): Unit

    Permalink
  114. abstract def enterRowFormatDelimited(ctx: RowFormatDelimitedContext): Unit

    Permalink
  115. abstract def enterRowFormatSerde(ctx: RowFormatSerdeContext): Unit

    Permalink
  116. abstract def enterSample(ctx: SampleContext): Unit

    Permalink
  117. abstract def enterScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): Unit

    Permalink
  118. abstract def enterSearchedCase(ctx: SearchedCaseContext): Unit

    Permalink
  119. abstract def enterSetConfiguration(ctx: SetConfigurationContext): Unit

    Permalink
  120. abstract def enterSetDatabaseProperties(ctx: SetDatabasePropertiesContext): Unit

    Permalink
  121. abstract def enterSetOperation(ctx: SetOperationContext): Unit

    Permalink
  122. abstract def enterSetQuantifier(ctx: SetQuantifierContext): Unit

    Permalink
  123. abstract def enterSetTableLocation(ctx: SetTableLocationContext): Unit

    Permalink
  124. abstract def enterSetTableProperties(ctx: SetTablePropertiesContext): Unit

    Permalink
  125. abstract def enterSetTableSerDe(ctx: SetTableSerDeContext): Unit

    Permalink
  126. abstract def enterShowColumns(ctx: ShowColumnsContext): Unit

    Permalink
  127. abstract def enterShowCreateTable(ctx: ShowCreateTableContext): Unit

    Permalink
  128. abstract def enterShowDatabases(ctx: ShowDatabasesContext): Unit

    Permalink
  129. abstract def enterShowFunctions(ctx: ShowFunctionsContext): Unit

    Permalink
  130. abstract def enterShowPartitions(ctx: ShowPartitionsContext): Unit

    Permalink
  131. abstract def enterShowTables(ctx: ShowTablesContext): Unit

    Permalink
  132. abstract def enterShowTblProperties(ctx: ShowTblPropertiesContext): Unit

    Permalink
  133. abstract def enterSimpleCase(ctx: SimpleCaseContext): Unit

    Permalink
  134. abstract def enterSingleDataType(ctx: SingleDataTypeContext): Unit

    Permalink
  135. abstract def enterSingleExpression(ctx: SingleExpressionContext): Unit

    Permalink
  136. abstract def enterSingleInsertQuery(ctx: SingleInsertQueryContext): Unit

    Permalink
  137. abstract def enterSingleStatement(ctx: SingleStatementContext): Unit

    Permalink
  138. abstract def enterSingleTableIdentifier(ctx: SingleTableIdentifierContext): Unit

    Permalink
  139. abstract def enterSkewSpec(ctx: SkewSpecContext): Unit

    Permalink
  140. abstract def enterSmallIntLiteral(ctx: SmallIntLiteralContext): Unit

    Permalink
  141. abstract def enterSortItem(ctx: SortItemContext): Unit

    Permalink
  142. abstract def enterStar(ctx: StarContext): Unit

    Permalink
  143. abstract def enterStatementDefault(ctx: StatementDefaultContext): Unit

    Permalink
  144. abstract def enterStorageHandler(ctx: StorageHandlerContext): Unit

    Permalink
  145. abstract def enterStringLiteral(ctx: StringLiteralContext): Unit

    Permalink
  146. abstract def enterSubquery(ctx: SubqueryContext): Unit

    Permalink
  147. abstract def enterSubqueryExpression(ctx: SubqueryExpressionContext): Unit

    Permalink
  148. abstract def enterSubscript(ctx: SubscriptContext): Unit

    Permalink
  149. abstract def enterTable(ctx: TableContext): Unit

    Permalink
  150. abstract def enterTableFileFormat(ctx: TableFileFormatContext): Unit

    Permalink
  151. abstract def enterTableIdentifier(ctx: TableIdentifierContext): Unit

    Permalink
  152. abstract def enterTableName(ctx: TableNameContext): Unit

    Permalink
  153. abstract def enterTableProperty(ctx: TablePropertyContext): Unit

    Permalink
  154. abstract def enterTablePropertyKey(ctx: TablePropertyKeyContext): Unit

    Permalink
  155. abstract def enterTablePropertyList(ctx: TablePropertyListContext): Unit

    Permalink
  156. abstract def enterTableProvider(ctx: TableProviderContext): Unit

    Permalink
  157. abstract def enterTinyIntLiteral(ctx: TinyIntLiteralContext): Unit

    Permalink
  158. abstract def enterTruncateTable(ctx: TruncateTableContext): Unit

    Permalink
  159. abstract def enterTypeConstructor(ctx: TypeConstructorContext): Unit

    Permalink
  160. abstract def enterUncacheTable(ctx: UncacheTableContext): Unit

    Permalink
  161. abstract def enterUnquotedIdentifier(ctx: UnquotedIdentifierContext): Unit

    Permalink
  162. abstract def enterUnsetTableProperties(ctx: UnsetTablePropertiesContext): Unit

    Permalink
  163. abstract def enterUnsupportedHiveNativeCommands(ctx: UnsupportedHiveNativeCommandsContext): Unit

    Permalink
  164. abstract def enterUse(ctx: UseContext): Unit

    Permalink
  165. abstract def enterValueExpressionDefault(ctx: ValueExpressionDefaultContext): Unit

    Permalink
  166. abstract def enterWhenClause(ctx: WhenClauseContext): Unit

    Permalink
  167. abstract def enterWindowDef(ctx: WindowDefContext): Unit

    Permalink
  168. abstract def enterWindowFrame(ctx: WindowFrameContext): Unit

    Permalink
  169. abstract def enterWindowRef(ctx: WindowRefContext): Unit

    Permalink
  170. abstract def enterWindows(ctx: WindowsContext): Unit

    Permalink
  171. abstract def exitAddResource(ctx: AddResourceContext): Unit

    Permalink
  172. abstract def exitAddTablePartition(ctx: AddTablePartitionContext): Unit

    Permalink
  173. abstract def exitAggregation(ctx: AggregationContext): Unit

    Permalink
  174. abstract def exitAliasedQuery(ctx: AliasedQueryContext): Unit

    Permalink
  175. abstract def exitAliasedRelation(ctx: AliasedRelationContext): Unit

    Permalink
  176. abstract def exitAlterViewQuery(ctx: AlterViewQueryContext): Unit

    Permalink
  177. abstract def exitAnalyze(ctx: AnalyzeContext): Unit

    Permalink
  178. abstract def exitArithmeticBinary(ctx: ArithmeticBinaryContext): Unit

    Permalink
  179. abstract def exitArithmeticOperator(ctx: ArithmeticOperatorContext): Unit

    Permalink
  180. abstract def exitArithmeticUnary(ctx: ArithmeticUnaryContext): Unit

    Permalink
  181. abstract def exitBigIntLiteral(ctx: BigIntLiteralContext): Unit

    Permalink
  182. abstract def exitBooleanDefault(ctx: BooleanDefaultContext): Unit

    Permalink
  183. abstract def exitBooleanLiteral(ctx: BooleanLiteralContext): Unit

    Permalink
  184. abstract def exitBooleanValue(ctx: BooleanValueContext): Unit

    Permalink
  185. abstract def exitBucketSpec(ctx: BucketSpecContext): Unit

    Permalink
  186. abstract def exitCacheTable(ctx: CacheTableContext): Unit

    Permalink
  187. abstract def exitCast(ctx: CastContext): Unit

    Permalink
  188. abstract def exitClearCache(ctx: ClearCacheContext): Unit

    Permalink
  189. abstract def exitColType(ctx: ColTypeContext): Unit

    Permalink
  190. abstract def exitColTypeList(ctx: ColTypeListContext): Unit

    Permalink
  191. abstract def exitColumnReference(ctx: ColumnReferenceContext): Unit

    Permalink
  192. abstract def exitComparison(ctx: ComparisonContext): Unit

    Permalink
  193. abstract def exitComparisonOperator(ctx: ComparisonOperatorContext): Unit

    Permalink
  194. abstract def exitComplexDataType(ctx: ComplexDataTypeContext): Unit

    Permalink
  195. abstract def exitConstantDefault(ctx: ConstantDefaultContext): Unit

    Permalink
  196. abstract def exitConstantList(ctx: ConstantListContext): Unit

    Permalink
  197. abstract def exitCreateDatabase(ctx: CreateDatabaseContext): Unit

    Permalink
  198. abstract def exitCreateFileFormat(ctx: CreateFileFormatContext): Unit

    Permalink
  199. abstract def exitCreateFunction(ctx: CreateFunctionContext): Unit

    Permalink
  200. abstract def exitCreateTable(ctx: CreateTableContext): Unit

    Permalink
  201. abstract def exitCreateTableHeader(ctx: CreateTableHeaderContext): Unit

    Permalink
  202. abstract def exitCreateTableLike(ctx: CreateTableLikeContext): Unit

    Permalink
  203. abstract def exitCreateTableUsing(ctx: CreateTableUsingContext): Unit

    Permalink
  204. abstract def exitCreateView(ctx: CreateViewContext): Unit

    Permalink
  205. abstract def exitCtes(ctx: CtesContext): Unit

    Permalink
  206. abstract def exitDecimalLiteral(ctx: DecimalLiteralContext): Unit

    Permalink
  207. abstract def exitDereference(ctx: DereferenceContext): Unit

    Permalink
  208. abstract def exitDescribeColName(ctx: DescribeColNameContext): Unit

    Permalink
  209. abstract def exitDescribeDatabase(ctx: DescribeDatabaseContext): Unit

    Permalink
  210. abstract def exitDescribeFuncName(ctx: DescribeFuncNameContext): Unit

    Permalink
  211. abstract def exitDescribeFunction(ctx: DescribeFunctionContext): Unit

    Permalink
  212. abstract def exitDescribeTable(ctx: DescribeTableContext): Unit

    Permalink
  213. abstract def exitDoubleLiteral(ctx: DoubleLiteralContext): Unit

    Permalink
  214. abstract def exitDropDatabase(ctx: DropDatabaseContext): Unit

    Permalink
  215. abstract def exitDropFunction(ctx: DropFunctionContext): Unit

    Permalink
  216. abstract def exitDropTable(ctx: DropTableContext): Unit

    Permalink
  217. abstract def exitDropTablePartitions(ctx: DropTablePartitionsContext): Unit

    Permalink
  218. abstract def exitEveryRule(arg0: ParserRuleContext): Unit

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

    Permalink
  220. abstract def exitExplain(ctx: ExplainContext): Unit

    Permalink
  221. abstract def exitExpression(ctx: ExpressionContext): Unit

    Permalink
  222. abstract def exitFailNativeCommand(ctx: FailNativeCommandContext): Unit

    Permalink
  223. abstract def exitFrameBound(ctx: FrameBoundContext): Unit

    Permalink
  224. abstract def exitFromClause(ctx: FromClauseContext): Unit

    Permalink
  225. abstract def exitFunctionCall(ctx: FunctionCallContext): Unit

    Permalink
  226. abstract def exitGenericFileFormat(ctx: GenericFileFormatContext): Unit

    Permalink
  227. abstract def exitGroupingSet(ctx: GroupingSetContext): Unit

    Permalink
  228. abstract def exitIdentifierComment(ctx: IdentifierCommentContext): Unit

    Permalink
  229. abstract def exitIdentifierCommentList(ctx: IdentifierCommentListContext): Unit

    Permalink
  230. abstract def exitIdentifierList(ctx: IdentifierListContext): Unit

    Permalink
  231. abstract def exitIdentifierSeq(ctx: IdentifierSeqContext): Unit

    Permalink
  232. abstract def exitInlineTable(ctx: InlineTableContext): Unit

    Permalink
  233. abstract def exitInlineTableDefault1(ctx: InlineTableDefault1Context): Unit

    Permalink
  234. abstract def exitInlineTableDefault2(ctx: InlineTableDefault2Context): Unit

    Permalink
  235. abstract def exitInsertInto(ctx: InsertIntoContext): Unit

    Permalink
  236. abstract def exitIntegerLiteral(ctx: IntegerLiteralContext): Unit

    Permalink
  237. abstract def exitInterval(ctx: IntervalContext): Unit

    Permalink
  238. abstract def exitIntervalField(ctx: IntervalFieldContext): Unit

    Permalink
  239. abstract def exitIntervalLiteral(ctx: IntervalLiteralContext): Unit

    Permalink
  240. abstract def exitIntervalValue(ctx: IntervalValueContext): Unit

    Permalink
  241. abstract def exitJoinCriteria(ctx: JoinCriteriaContext): Unit

    Permalink
  242. abstract def exitJoinRelation(ctx: JoinRelationContext): Unit

    Permalink
  243. abstract def exitJoinType(ctx: JoinTypeContext): Unit

    Permalink
  244. abstract def exitLateralView(ctx: LateralViewContext): Unit

    Permalink
  245. abstract def exitLoadData(ctx: LoadDataContext): Unit

    Permalink
  246. abstract def exitLocationSpec(ctx: LocationSpecContext): Unit

    Permalink
  247. abstract def exitLogicalBinary(ctx: LogicalBinaryContext): Unit

    Permalink
  248. abstract def exitLogicalNot(ctx: LogicalNotContext): Unit

    Permalink
  249. abstract def exitLooseIdentifier(ctx: LooseIdentifierContext): Unit

    Permalink
  250. abstract def exitMultiInsertQuery(ctx: MultiInsertQueryContext): Unit

    Permalink
  251. abstract def exitMultiInsertQueryBody(ctx: MultiInsertQueryBodyContext): Unit

    Permalink
  252. abstract def exitNamedExpression(ctx: NamedExpressionContext): Unit

    Permalink
  253. abstract def exitNamedExpressionSeq(ctx: NamedExpressionSeqContext): Unit

    Permalink
  254. abstract def exitNamedQuery(ctx: NamedQueryContext): Unit

    Permalink
  255. abstract def exitNamedWindow(ctx: NamedWindowContext): Unit

    Permalink
  256. abstract def exitNestedConstantList(ctx: NestedConstantListContext): Unit

    Permalink
  257. abstract def exitNonReserved(ctx: NonReservedContext): Unit

    Permalink
  258. abstract def exitNullLiteral(ctx: NullLiteralContext): Unit

    Permalink
  259. abstract def exitNumericLiteral(ctx: NumericLiteralContext): Unit

    Permalink
  260. abstract def exitOrderedIdentifier(ctx: OrderedIdentifierContext): Unit

    Permalink
  261. abstract def exitOrderedIdentifierList(ctx: OrderedIdentifierListContext): Unit

    Permalink
  262. abstract def exitParenthesizedExpression(ctx: ParenthesizedExpressionContext): Unit

    Permalink
  263. abstract def exitPartitionSpec(ctx: PartitionSpecContext): Unit

    Permalink
  264. abstract def exitPartitionSpecLocation(ctx: PartitionSpecLocationContext): Unit

    Permalink
  265. abstract def exitPartitionVal(ctx: PartitionValContext): Unit

    Permalink
  266. abstract def exitPredicate(ctx: PredicateContext): Unit

    Permalink
  267. abstract def exitPredicateOperator(ctx: PredicateOperatorContext): Unit

    Permalink
  268. abstract def exitPredicated(ctx: PredicatedContext): Unit

    Permalink
  269. abstract def exitPrimitiveDataType(ctx: PrimitiveDataTypeContext): Unit

    Permalink
  270. abstract def exitQualifiedName(ctx: QualifiedNameContext): Unit

    Permalink
  271. abstract def exitQuery(ctx: QueryContext): Unit

    Permalink
  272. abstract def exitQueryOrganization(ctx: QueryOrganizationContext): Unit

    Permalink
  273. abstract def exitQueryPrimaryDefault(ctx: QueryPrimaryDefaultContext): Unit

    Permalink
  274. abstract def exitQuerySpecification(ctx: QuerySpecificationContext): Unit

    Permalink
  275. abstract def exitQueryTermDefault(ctx: QueryTermDefaultContext): Unit

    Permalink
  276. abstract def exitQuotedIdentifier(ctx: QuotedIdentifierContext): Unit

    Permalink
  277. abstract def exitQuotedIdentifierAlternative(ctx: QuotedIdentifierAlternativeContext): Unit

    Permalink
  278. abstract def exitRefreshTable(ctx: RefreshTableContext): Unit

    Permalink
  279. abstract def exitRelationDefault(ctx: RelationDefaultContext): Unit

    Permalink
  280. abstract def exitRenameTable(ctx: RenameTableContext): Unit

    Permalink
  281. abstract def exitRenameTablePartition(ctx: RenameTablePartitionContext): Unit

    Permalink
  282. abstract def exitResource(ctx: ResourceContext): Unit

    Permalink
  283. abstract def exitRowConstructor(ctx: RowConstructorContext): Unit

    Permalink
  284. abstract def exitRowFormatDelimited(ctx: RowFormatDelimitedContext): Unit

    Permalink
  285. abstract def exitRowFormatSerde(ctx: RowFormatSerdeContext): Unit

    Permalink
  286. abstract def exitSample(ctx: SampleContext): Unit

    Permalink
  287. abstract def exitScientificDecimalLiteral(ctx: ScientificDecimalLiteralContext): Unit

    Permalink
  288. abstract def exitSearchedCase(ctx: SearchedCaseContext): Unit

    Permalink
  289. abstract def exitSetConfiguration(ctx: SetConfigurationContext): Unit

    Permalink
  290. abstract def exitSetDatabaseProperties(ctx: SetDatabasePropertiesContext): Unit

    Permalink
  291. abstract def exitSetOperation(ctx: SetOperationContext): Unit

    Permalink
  292. abstract def exitSetQuantifier(ctx: SetQuantifierContext): Unit

    Permalink
  293. abstract def exitSetTableLocation(ctx: SetTableLocationContext): Unit

    Permalink
  294. abstract def exitSetTableProperties(ctx: SetTablePropertiesContext): Unit

    Permalink
  295. abstract def exitSetTableSerDe(ctx: SetTableSerDeContext): Unit

    Permalink
  296. abstract def exitShowColumns(ctx: ShowColumnsContext): Unit

    Permalink
  297. abstract def exitShowCreateTable(ctx: ShowCreateTableContext): Unit

    Permalink
  298. abstract def exitShowDatabases(ctx: ShowDatabasesContext): Unit

    Permalink
  299. abstract def exitShowFunctions(ctx: ShowFunctionsContext): Unit

    Permalink
  300. abstract def exitShowPartitions(ctx: ShowPartitionsContext): Unit

    Permalink
  301. abstract def exitShowTables(ctx: ShowTablesContext): Unit

    Permalink
  302. abstract def exitShowTblProperties(ctx: ShowTblPropertiesContext): Unit

    Permalink
  303. abstract def exitSimpleCase(ctx: SimpleCaseContext): Unit

    Permalink
  304. abstract def exitSingleDataType(ctx: SingleDataTypeContext): Unit

    Permalink
  305. abstract def exitSingleExpression(ctx: SingleExpressionContext): Unit

    Permalink
  306. abstract def exitSingleInsertQuery(ctx: SingleInsertQueryContext): Unit

    Permalink
  307. abstract def exitSingleStatement(ctx: SingleStatementContext): Unit

    Permalink
  308. abstract def exitSingleTableIdentifier(ctx: SingleTableIdentifierContext): Unit

    Permalink
  309. abstract def exitSkewSpec(ctx: SkewSpecContext): Unit

    Permalink
  310. abstract def exitSmallIntLiteral(ctx: SmallIntLiteralContext): Unit

    Permalink
  311. abstract def exitSortItem(ctx: SortItemContext): Unit

    Permalink
  312. abstract def exitStar(ctx: StarContext): Unit

    Permalink
  313. abstract def exitStatementDefault(ctx: StatementDefaultContext): Unit

    Permalink
  314. abstract def exitStorageHandler(ctx: StorageHandlerContext): Unit

    Permalink
  315. abstract def exitStringLiteral(ctx: StringLiteralContext): Unit

    Permalink
  316. abstract def exitSubquery(ctx: SubqueryContext): Unit

    Permalink
  317. abstract def exitSubqueryExpression(ctx: SubqueryExpressionContext): Unit

    Permalink
  318. abstract def exitSubscript(ctx: SubscriptContext): Unit

    Permalink
  319. abstract def exitTable(ctx: TableContext): Unit

    Permalink
  320. abstract def exitTableFileFormat(ctx: TableFileFormatContext): Unit

    Permalink
  321. abstract def exitTableIdentifier(ctx: TableIdentifierContext): Unit

    Permalink
  322. abstract def exitTableName(ctx: TableNameContext): Unit

    Permalink
  323. abstract def exitTableProperty(ctx: TablePropertyContext): Unit

    Permalink
  324. abstract def exitTablePropertyKey(ctx: TablePropertyKeyContext): Unit

    Permalink
  325. abstract def exitTablePropertyList(ctx: TablePropertyListContext): Unit

    Permalink
  326. abstract def exitTableProvider(ctx: TableProviderContext): Unit

    Permalink
  327. abstract def exitTinyIntLiteral(ctx: TinyIntLiteralContext): Unit

    Permalink
  328. abstract def exitTruncateTable(ctx: TruncateTableContext): Unit

    Permalink
  329. abstract def exitTypeConstructor(ctx: TypeConstructorContext): Unit

    Permalink
  330. abstract def exitUncacheTable(ctx: UncacheTableContext): Unit

    Permalink
  331. abstract def exitUnquotedIdentifier(ctx: UnquotedIdentifierContext): Unit

    Permalink
  332. abstract def exitUnsetTableProperties(ctx: UnsetTablePropertiesContext): Unit

    Permalink
  333. abstract def exitUnsupportedHiveNativeCommands(ctx: UnsupportedHiveNativeCommandsContext): Unit

    Permalink
  334. abstract def exitUse(ctx: UseContext): Unit

    Permalink
  335. abstract def exitValueExpressionDefault(ctx: ValueExpressionDefaultContext): Unit

    Permalink
  336. abstract def exitWhenClause(ctx: WhenClauseContext): Unit

    Permalink
  337. abstract def exitWindowDef(ctx: WindowDefContext): Unit

    Permalink
  338. abstract def exitWindowFrame(ctx: WindowFrameContext): Unit

    Permalink
  339. abstract def exitWindowRef(ctx: WindowRefContext): Unit

    Permalink
  340. abstract def exitWindows(ctx: WindowsContext): Unit

    Permalink
  341. abstract def visitErrorNode(arg0: ErrorNode): Unit

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

    Permalink
    Definition Classes
    ParseTreeListener

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 ParseTreeListener

Inherited from AnyRef

Inherited from Any

Ungrouped