BuiltInSqlFunction |
|
BuiltInSqlFunction.Builder |
Builder for fluent definition of built-in functions.
|
FlinkCurrentDateDynamicFunction |
The Flink CURRENT_DATE function differs from the parent SqlCurrentDateFunction which is
aware of whether it is used in batch mode, if true it will act totally same as the parent SqlCurrentDateFunction , but will be a non-deterministic function if not in batch mode.
|
FlinkCurrentRowTimestampFunction |
The function CURRENT_ROW_TIMESTAMP() in Flink which supports configuring the return type and the
precision of return type.
|
FlinkSqlOperatorTable |
Operator table that contains only Flink-specific functions and operators.
|
FlinkTimestampDynamicFunction |
Function that used to define SQL time functions like LOCALTIME, CURRENT_TIME(these are all
dynamic functions in Calcite's SqlStdOperatorTable ) in Flink, the difference from the
parent SqlAbstractTimeFunction is this function class be aware of whether it is used in
batch mode, if true it will act totally same as the parent SqlAbstractTimeFunction , but
will be a non-deterministic function if not in batch mode.
|
FlinkTimestampWithPrecisionDynamicFunction |
Function that used to define SQL time function like LOCALTIMESTAMP, CURRENT_TIMESTAMP, NOW() in
Flink, the function support configuring the return type and the * precision of return type.
|
MatchRowTimeFunction |
The function used to access a rowtime attribute with TIMESTAMP or TIMESTAMP_LTZ type from
MATCH_RECOGNIZE clause.
|
SqlArrayConstructor |
SqlOperator for ARRAY , which makes explicit casting if the element type not
equals the derived component type.
|
SqlCumulateTableFunction |
SqlCumulateTableFunction implements an operator for cumulative.
|
SqlDefaultOperator |
Default operator has specified type.
|
SqlDescriptorOperator |
DESCRIPTOR appears as an argument in a function.
|
SqlFirstLastValueAggFunction |
FIRST_VALUE and LAST_VALUE aggregate functions return the first or the
last value in a list of values that are input to the function.
|
SqlHopTableFunction |
SqlHopTableFunction implements an operator for hopping.
|
SqlListAggFunction |
LISTAGG aggregate function returns the concatenation of a list of values that are
input to the function.
|
SqlMapConstructor |
SqlOperator for MAP , which makes explicit casting if the element type not
equals the derived component type.
|
SqlSessionTableFunction |
SqlSessionTableFunction implements an operator for per-key sessionization.
|
SqlThrowExceptionFunction |
Function used to throw an exception, only used internally.
|
SqlTryCastFunction |
This class implements the TRY_CAST built-in, essentially delegating all the method
invocations, whenever is possible, to Calcite's SqlCastFunction .
|
SqlTumbleTableFunction |
SqlTumbleTableFunction implements an operator for tumbling.
|
SqlWindowTableFunction |
Base class for a table-valued function that computes windows.
|
SqlWindowTableFunction.AbstractOperandMetadata |
Partial implementation of operand type checker.
|