@Internal public class BridgingSqlFunction extends org.apache.calcite.sql.SqlFunction
FunctionDefinition
to Calcite's representation of a scalar or table function
(either a system or user-defined function).Modifier and Type | Class and Description |
---|---|
static class |
BridgingSqlFunction.WithTableFunction
Special flavor of
BridgingSqlFunction to indicate a table function to Calcite. |
Modifier and Type | Method and Description |
---|---|
DataTypeFactory |
getDataTypeFactory() |
FunctionDefinition |
getDefinition() |
List<String> |
getParamNames() |
ContextResolvedFunction |
getResolvedFunction() |
RexFactory |
getRexFactory() |
org.apache.flink.table.planner.calcite.FlinkTypeFactory |
getTypeFactory() |
TypeInference |
getTypeInference() |
boolean |
isDeterministic() |
static BridgingSqlFunction |
of(DataTypeFactory dataTypeFactory,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
RexFactory rexFactory,
org.apache.calcite.sql.SqlKind kind,
ContextResolvedFunction resolvedFunction,
TypeInference typeInference)
Creates an instance of a scalar or table function (either a system or user-defined function).
|
static BridgingSqlFunction |
of(org.apache.flink.table.planner.calcite.FlinkContext context,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
ContextResolvedFunction resolvedFunction)
Creates an instance of a scalar or table function during translation.
|
static BridgingSqlFunction |
of(org.apache.calcite.plan.RelOptCluster cluster,
BuiltInFunctionDefinition functionDefinition)
Creates an instance of a scalar or table built-in function during translation.
|
static BridgingSqlFunction |
of(org.apache.calcite.plan.RelOptCluster cluster,
ContextResolvedFunction resolvedFunction)
Creates an instance of a scalar or table function during translation.
|
deriveType, getFunctionType, getNameAsId, getParamTypes, getSqlIdentifier, getSyntax, isQuantifierAllowed, unparse, validateCall, validateQuantifier
acceptCall, acceptCall, adjustType, allowsFraming, argumentMustBeScalar, checkOperandCount, checkOperandTypes, constructArgNameList, constructArgTypeList, constructOperandList, createCall, createCall, createCall, createCall, createCall, createCall, createCall, 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
public static BridgingSqlFunction of(DataTypeFactory dataTypeFactory, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, RexFactory rexFactory, org.apache.calcite.sql.SqlKind kind, ContextResolvedFunction resolvedFunction, TypeInference typeInference)
dataTypeFactory
- used for creating DataType
typeFactory
- used for bridging to RelDataType
rexFactory
- used for SpecializedFunction.ExpressionEvaluatorFactory
kind
- commonly used SQL standard function; use SqlKind.OTHER_FUNCTION
if this
function cannot be mapped to a common function kind.resolvedFunction
- system or user-defined FunctionDefinition
with contexttypeInference
- type inference logicpublic static BridgingSqlFunction of(org.apache.flink.table.planner.calcite.FlinkContext context, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, ContextResolvedFunction resolvedFunction)
public static BridgingSqlFunction of(org.apache.calcite.plan.RelOptCluster cluster, ContextResolvedFunction resolvedFunction)
public static BridgingSqlFunction of(org.apache.calcite.plan.RelOptCluster cluster, BuiltInFunctionDefinition functionDefinition)
public DataTypeFactory getDataTypeFactory()
public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
public RexFactory getRexFactory()
public ContextResolvedFunction getResolvedFunction()
public FunctionDefinition getDefinition()
public TypeInference getTypeInference()
public List<String> getParamNames()
getParamNames
in class org.apache.calcite.sql.SqlFunction
public boolean isDeterministic()
isDeterministic
in class org.apache.calcite.sql.SqlOperator
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.