Class BridgingSqlFunction.WithTableFunction
- java.lang.Object
-
- org.apache.calcite.sql.SqlOperator
-
- org.apache.calcite.sql.SqlFunction
-
- org.apache.flink.table.planner.functions.bridging.BridgingSqlFunction
-
- org.apache.flink.table.planner.functions.bridging.BridgingSqlFunction.WithTableFunction
-
- All Implemented Interfaces:
org.apache.calcite.sql.SqlTableFunction
- Enclosing class:
- BridgingSqlFunction
public static class BridgingSqlFunction.WithTableFunction extends BridgingSqlFunction implements org.apache.calcite.sql.SqlTableFunction
Special flavor ofBridgingSqlFunction
to indicate a table function to Calcite.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.table.planner.functions.bridging.BridgingSqlFunction
BridgingSqlFunction.WithTableFunction
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.calcite.sql.type.SqlReturnTypeInference
getRowTypeInference()
The conversion to a row type is handled on the caller side.-
Methods inherited from class org.apache.flink.table.planner.functions.bridging.BridgingSqlFunction
getDataTypeFactory, getDefinition, getParamNames, getResolvedFunction, getRexFactory, getTypeFactory, getTypeInference, isDeterministic, of, of, of, of
-
Methods inherited from class org.apache.calcite.sql.SqlFunction
deriveType, getFunctionType, getNameAsId, getParamTypes, getSqlIdentifier, getSyntax, isQuantifierAllowed, unparse, validateCall, validateQuantifier
-
Methods inherited from class org.apache.calcite.sql.SqlOperator
acceptCall, acceptCall, adjustType, allowsFraming, argumentMustBeScalar, checkOperandCount, checkOperandTypes, constructArgNameList, constructArgTypeList, constructOperandList, createCall, createCall, createCall, createCall, createCall, createCall, createCall, deriveOperandType, equals, getAllowedSignatures, getAllowedSignatures, getKind, getLeftPrec, getMonotonicity, getMonotonicity, getName, getOperandCountRange, getOperandTypeChecker, getOperandTypeInference, getReturnTypeInference, getRightPrec, getSignatureTemplate, getStrongPolicyInference, hashCode, inferReturnType, inferReturnType, isAggregator, isDynamicFunction, isGroup, isGroupAuxiliary, isName, isSymmetrical, leftPrec, not, preValidateCall, requiresDecimalExpansion, requiresOrder, requiresOver, reverse, rewriteCall, rightPrec, toString, unparseListClause, unparseListClause, validateOperands, validRexOperands
-
-
-
-
Method Detail
-
getRowTypeInference
public org.apache.calcite.sql.type.SqlReturnTypeInference getRowTypeInference()
The conversion to a row type is handled on the caller side. This allows us to perform it SQL/Table API-specific. This is in particular important to set the aliases of fields correctly (seeFlinkRelBuilder.pushFunctionScan(RelBuilder, SqlOperator, int, Iterable, List)
).- Specified by:
getRowTypeInference
in interfaceorg.apache.calcite.sql.SqlTableFunction
-
-