void |
StormParserImpl.Arg(List list,
org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
|
void |
StormParserImpl.Arg0(List list,
org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.ArrayConstructor() |
Parses an ARRAY constructor
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.AtomicRowExpression() |
Parses an atomic row expression.
|
org.apache.calcite.sql.SqlBinaryOperator |
StormParserImpl.BinaryMultisetOperator() |
Parses a binary multiset operator.
|
org.apache.calcite.sql.SqlBinaryOperator |
StormParserImpl.BinaryQueryOperator() |
Parses a binary query operator like UNION.
|
org.apache.calcite.sql.SqlBinaryOperator |
StormParserImpl.BinaryRowOperator() |
Parses a binary row operator like AND.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.BuiltinFunctionCall() |
Parses a call to a builtin function with special syntax.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.CaseExpression() |
|
org.apache.calcite.sql.SqlCollation |
StormParserImpl.CollateClause() |
Parses a COLLATE clause
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.CollectionsTypeName() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ColumnDefinitionList() |
|
void |
StormParserImpl.ColumnType(List<org.apache.calcite.sql.SqlNode> list) |
|
String |
StormParserImpl.CommonNonReservedKeyWord() |
Parses a non-reserved keyword for use as an identifier.
|
org.apache.calcite.sql.SqlKind |
StormParserImpl.comp() |
Parses a comparison operator inside a SOME / ALL predicate.
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.CompoundIdentifier() |
Parses a compound identifier.
|
void |
StormParserImpl.CompoundIdentifierType(List<org.apache.calcite.sql.SqlNode> list,
List<org.apache.calcite.sql.SqlNode> extendList) |
Parses a compound identifier with optional type.
|
void |
StormParserImpl.CompoundIdentifierTypeCommaList(List<org.apache.calcite.sql.SqlNode> list,
List<org.apache.calcite.sql.SqlNode> extendList) |
Parses a comma-separated list of compound identifiers.
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.ContextVariable() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.CursorExpression(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a CURSOR(query) expression.
|
org.apache.calcite.sql.SqlDataTypeSpec |
StormParserImpl.DataType() |
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.DateTimeLiteral() |
Parses a date/time literal.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.Default() |
|
org.apache.calcite.sql.SqlDynamicParam |
StormParserImpl.DynamicParam() |
Parses a dynamic parameter marker.
|
org.apache.calcite.sql.SqlExplain.Depth |
StormParserImpl.ExplainDepth() |
Parses WITH TYPE | WITH IMPLEMENTATION | WITHOUT IMPLEMENTATION modifier for
EXPLAIN PLAN.
|
org.apache.calcite.sql.SqlExplainLevel |
StormParserImpl.ExplainDetailLevel() |
Parses INCLUDING ALL ATTRIBUTES modifier for EXPLAIN PLAN.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.ExplicitTable(org.apache.calcite.sql.parser.SqlParserPos pos) |
Parses an explicit TABLE t reference.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.Expression(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a row expression or a parenthesized expression of any kind.
|
List<Object> |
StormParserImpl.Expression2(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a binary row expression, or a parenthesized expression of any
kind.
|
void |
StormParserImpl.Expression2b(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext,
List<Object> list) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.Expression3(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a unary row expression, or a parenthesized expression of any
kind.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ExpressionCommaList(org.apache.calcite.sql.parser.Span s,
org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a list of expressions separated by commas.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.ExtendedBuiltinFunctionCall() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.ExtendedTableRef() |
Allows parser to be extended with new types of table references.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ExtendList() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.FloorCeilOptions(org.apache.calcite.sql.parser.Span s,
boolean floorFlag) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.FromClause() |
Parses the FROM clause for a SELECT.
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.FunctionName() |
Parses the name of a function (either a compound identifier or
a reserved word which can be used as a function name).
|
List |
StormParserImpl.FunctionParameterList(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses function parameter lists including DISTINCT keyword recognition,
DEFAULT, and named argument assignment.
|
protected org.apache.calcite.sql.parser.SqlParserPos |
StormParserImpl.getPos() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.GroupByOpt() |
Parses the optional GROUP BY clause for SELECT.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.GroupingElement() |
|
List<org.apache.calcite.sql.SqlNode> |
StormParserImpl.GroupingElementList() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.HavingOpt() |
Parses the optional HAVING clause for SELECT.
|
String |
StormParserImpl.Identifier() |
Parses a simple identifier as a string.
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.IntervalLiteral() |
Parses an interval literal.
|
org.apache.calcite.sql.SqlIntervalQualifier |
StormParserImpl.IntervalQualifier() |
|
int |
StormParserImpl.IntLiteral() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.JdbcFunctionCall() |
Parses a function call expression with JDBC syntax.
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.JdbcOdbcDataType() |
|
org.apache.calcite.sql.SqlJdbcDataTypeName |
StormParserImpl.JdbcOdbcDataTypeName() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.JoinTable(org.apache.calcite.sql.SqlNode e) |
Matches "LEFT JOIN t ON ...", "RIGHT JOIN t USING ...", "JOIN t".
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.JoinType() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.LeafQuery(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a leaf in a query expression (SELECT, VALUES or TABLE).
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.LeafQueryOrExpr(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses either a row expression, a leaf query expression, or
a parenthesized expression of any kind.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.Literal() |
Parses a literal expression, allowing continued string literals.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.MapConstructor() |
Parses a MAP constructor
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.MatchRecognizeCallWithModifier() |
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.MatchRecognizeFunctionCall() |
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.MatchRecognizeNavigationLogical() |
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.MatchRecognizeNavigationPhysical() |
|
org.apache.calcite.sql.SqlMatchRecognize |
StormParserImpl.MatchRecognizeOpt(org.apache.calcite.sql.SqlNode tableRef) |
Parses a MATCH_RECOGNIZE clause following a table expression.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.MeasureColumn() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.MeasureColumnCommaList(org.apache.calcite.sql.parser.Span s) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.MultisetConstructor() |
Parses a MULTISET constructor
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.NamedFunctionCall() |
Parses a call to a named function (could be a builtin with regular
syntax, or else a UDF).
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.NamedRoutineCall(org.apache.calcite.sql.SqlFunctionCategory routineType,
org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.Natural() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.NewSpecification() |
Parses a NEW UDT(...) expression.
|
String |
StormParserImpl.NonReservedJdbcFunctionName() |
Parses the name of a JDBC function that is a token but is not reserved.
|
String |
StormParserImpl.NonReservedKeyWord() |
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.NumericLiteral() |
Parses a numeric literal (can be signed)
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.OrderBy(boolean accept) |
Parses an ORDER BY clause.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.OrderedQueryOrExpr(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses either a row expression or a query expression with an optional
ORDER BY.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.OrderItem() |
Parses one list item in an ORDER BY clause.
|
org.apache.calcite.util.Pair<org.apache.calcite.sql.SqlNodeList,org.apache.calcite.sql.SqlNodeList> |
StormParserImpl.ParenthesizedCompoundIdentifierList() |
List of compound identifiers in parentheses.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.ParenthesizedExpression(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a parenthesized query or single row expression.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ParenthesizedQueryOrCommaList(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses a parenthesized query or comma-list of row expressions.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ParenthesizedQueryOrCommaListWithDefault(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
As ParenthesizedQueryOrCommaList, but allows DEFAULT
in place of any of the expressions.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.ParenthesizedSimpleIdentifierList() |
List of simple identifiers in parentheses.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PatternDefinition() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.PatternDefinitionCommaList(org.apache.calcite.sql.parser.Span s) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PatternExpression() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PatternFactor() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PatternPrimary() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PatternTerm() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.PeriodConstructor() |
Parses a PERIOD constructor
|
org.apache.calcite.sql.SqlOperator |
StormParserImpl.periodOperator() |
|
org.apache.calcite.sql.SqlPostfixOperator |
StormParserImpl.PostfixRowOperator() |
Parses a postfix row operator like IS NOT NULL.
|
org.apache.calcite.sql.SqlPrefixOperator |
StormParserImpl.PrefixRowOperator() |
Parses a prefix row operator like NOT.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.QueryOrExpr(org.apache.calcite.sql.parser.SqlAbstractParserImpl.ExprContext exprContext) |
Parses either a row expression or a query expression without ORDER BY.
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.ReservedFunctionName() |
Parses a reserved word which is used as the name of a function.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.RowConstructor() |
Parses a row constructor in the context of a VALUES expression.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.RowConstructorList(org.apache.calcite.sql.parser.Span s) |
Parses one or more rows in a VALUES expression.
|
String |
StormParserImpl.Scope() |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SelectExpression() |
Parses one unaliased expression in a select list.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SelectItem() |
Parses one item in a select list.
|
List<org.apache.calcite.sql.SqlNode> |
StormParserImpl.SelectList() |
Parses the select list of a SELECT statement.
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.SequenceExpression() |
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.SimpleIdentifier() |
Parses a simple identifier as an SqlIdentifier.
|
void |
StormParserImpl.SimpleIdentifierCommaList(List<org.apache.calcite.sql.SqlNode> list) |
Parses a comma-separated list of simple identifiers.
|
org.apache.calcite.sql.SqlLiteral |
StormParserImpl.SpecialLiteral() |
Parse a special literal keyword
|
org.apache.calcite.sql.SqlAlter |
StormParserImpl.SqlAlter() |
Parses an expression for setting or resetting an option in SQL, such as QUOTED_IDENTIFIERS,
or explain plan level (physical/logical).
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlCreateFunction() |
CREATE FUNCTION functionname AS 'classname'
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlCreateTable() |
CREATE EXTERNAL TABLE ( IF NOT EXISTS )?
( database_name '.' )? table_name ( '(' column_def ( ',' column_def )* ')'
( STORED AS INPUTFORMAT input_format_classname OUTPUTFORMAT output_format_classname )?
LOCATION location_uri
( TBLPROPERTIES tbl_properties )?
( AS select_stmt )
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlDelete() |
Parses a DELETE statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlDescribe() |
Parses a DESCRIBE statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlExplain() |
Parses an EXPLAIN PLAN statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlExpressionEof() |
Parses a SQL expression (such as might occur in a WHERE clause) followed by
the end-of-file symbol.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlInsert() |
Parses an INSERT statement.
|
void |
StormParserImpl.SqlInsertKeywords(List<org.apache.calcite.sql.SqlLiteral> keywords) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlMerge() |
Parses a MERGE statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlProcedureCall() |
Parses a CALL statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlQueryEof() |
Parses a query (SELECT, UNION, INTERSECT, EXCEPT, VALUES, TABLE) followed by
the end-of-file symbol.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlQueryOrDml() |
Parses a query (SELECT or VALUES)
or DML statement (INSERT, UPDATE, DELETE, MERGE).
|
org.apache.calcite.sql.SqlSelect |
StormParserImpl.SqlSelect() |
Parses a leaf SELECT expression without ORDER BY.
|
void |
StormParserImpl.SqlSelectKeywords(List<org.apache.calcite.sql.SqlLiteral> keywords) |
|
org.apache.calcite.sql.SqlSetOption |
StormParserImpl.SqlSetOption(org.apache.calcite.sql.parser.Span s,
String scope) |
Parses "SET <NAME> = VALUE" or "RESET <NAME>", without a leading
"ALTER <SCOPE>".
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlStmt() |
Parses an SQL statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlStmtEof() |
Parses an SQL statement followed by the end-of-file symbol.
|
org.apache.calcite.sql.type.SqlTypeName |
StormParserImpl.SqlTypeName(org.apache.calcite.sql.parser.Span s) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SqlUpdate() |
Parses an UPDATE statement.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.StandardFloorCeilOptions(org.apache.calcite.sql.parser.Span s,
boolean floorFlag) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.StringLiteral() |
Parses a string literal.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.SubsetDefinition() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.SubsetDefinitionCommaList(org.apache.calcite.sql.parser.Span s) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.TableConstructor() |
Parses a VALUES leaf query expression.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.TableFunctionCall(org.apache.calcite.sql.parser.SqlParserPos pos) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.TableOverOpt() |
Allows an OVER clause following a table expression as an extension to
standard SQL syntax.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.TableRef() |
Parses a table reference in a FROM clause, not lateral unless LATERAL
is explicitly specified.
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.TableRef2(boolean lateral) |
Parses a table reference in a FROM clause.
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.TimestampAddFunctionCall() |
Parses a call to TIMESTAMPADD.
|
org.apache.calcite.sql.SqlCall |
StormParserImpl.TimestampDiffFunctionCall() |
Parses a call to TIMESTAMPDIFF.
|
org.apache.calcite.avatica.util.TimeUnit |
StormParserImpl.TimestampInterval() |
|
org.apache.calcite.avatica.util.TimeUnit |
StormParserImpl.TimeUnit() |
Parses time unit for EXTRACT, CEIL and FLOOR functions.
|
org.apache.calcite.sql.SqlIdentifier |
StormParserImpl.TypeName() |
|
int |
StormParserImpl.UnsignedIntLiteral() |
|
org.apache.calcite.sql.SqlNumericLiteral |
StormParserImpl.UnsignedNumericLiteral() |
Parses a unsigned numeric literal
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.UnsignedNumericLiteralOrParam() |
Numeric literal or parameter; used in LIMIT, OFFSET and FETCH clauses.
|
void |
StormParserImpl.UnusedExtension() |
Defines a production which can never be accepted by the parser.
|
org.apache.calcite.sql.SqlUpdate |
StormParserImpl.WhenMatchedClause(org.apache.calcite.sql.SqlNode table,
org.apache.calcite.sql.SqlIdentifier alias) |
|
org.apache.calcite.sql.SqlInsert |
StormParserImpl.WhenNotMatchedClause(org.apache.calcite.sql.SqlNode table) |
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.WhereOpt() |
Parses the optional WHERE clause for SELECT, DELETE, and UPDATE.
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.WindowOpt() |
Parses the optional WINDOW clause for SELECT
|
org.apache.calcite.sql.SqlNode |
StormParserImpl.WindowRange() |
|
org.apache.calcite.sql.SqlWindow |
StormParserImpl.WindowSpecification() |
Parses a window specification.
|
org.apache.calcite.sql.SqlWithItem |
StormParserImpl.WithItem() |
|
org.apache.calcite.sql.SqlNodeList |
StormParserImpl.WithList() |
|