@Internal public final class BridgingSqlAggFunction extends org.apache.calcite.sql.SqlAggFunction
FunctionDefinition
to Calcite's representation of an aggregating function (either
a system or user-defined function).Modifier and Type | Method and Description |
---|---|
DataTypeFactory |
getDataTypeFactory() |
FunctionDefinition |
getDefinition() |
List<String> |
getParamNames() |
List<org.apache.calcite.rel.type.RelDataType> |
getParamTypes() |
ContextResolvedFunction |
getResolvedFunction() |
org.apache.flink.table.planner.calcite.FlinkTypeFactory |
getTypeFactory() |
TypeInference |
getTypeInference() |
boolean |
isDeterministic() |
static BridgingSqlAggFunction |
of(DataTypeFactory dataTypeFactory,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
org.apache.calcite.sql.SqlKind kind,
ContextResolvedFunction resolvedFunction,
TypeInference typeInference)
Creates an instance of a aggregating function (either a system or user-defined function).
|
static BridgingSqlAggFunction |
of(org.apache.flink.table.planner.calcite.FlinkContext context,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
ContextResolvedFunction resolvedFunction)
Creates an instance of a aggregate function during translation.
|
allowsFilter, allowsNullTreatment, getDistinctOptionality, getParameterTypes, getReturnType, isAggregator, isQuantifierAllowed, requiresGroupOrder, requiresOrder, requiresOver, unwrap, validateCall
deriveType, getFunctionType, getNameAsId, getSqlIdentifier, getSyntax, unparse, validateQuantifier
acceptCall, acceptCall, adjustType, allowsFraming, argumentMustBeScalar, checkOperandCount, checkOperandTypes, constructArgNameList, constructArgTypeList, constructOperandList, createCall, createCall, createCall, createCall, equals, getAllowedSignatures, getAllowedSignatures, getKind, getLeftPrec, getMonotonicity, getMonotonicity, getName, getOperandCountRange, getOperandTypeChecker, getOperandTypeInference, getReturnTypeInference, getRightPrec, getSignatureTemplate, getStrongPolicyInference, hashCode, inferReturnType, inferReturnType, isDynamicFunction, isGroup, isGroupAuxiliary, isName, isSymmetrical, leftPrec, preValidateCall, requiresDecimalExpansion, rewriteCall, rightPrec, toString, unparseListClause, unparseListClause, validateOperands, validRexOperands
public static BridgingSqlAggFunction of(DataTypeFactory dataTypeFactory, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, org.apache.calcite.sql.SqlKind kind, ContextResolvedFunction resolvedFunction, TypeInference typeInference)
dataTypeFactory
- used for creating DataType
typeFactory
- used for bridging to RelDataType
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 BridgingSqlAggFunction of(org.apache.flink.table.planner.calcite.FlinkContext context, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, ContextResolvedFunction resolvedFunction)
public DataTypeFactory getDataTypeFactory()
public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
public ContextResolvedFunction getResolvedFunction()
public FunctionDefinition getDefinition()
public TypeInference getTypeInference()
public List<org.apache.calcite.rel.type.RelDataType> getParamTypes()
getParamTypes
in class org.apache.calcite.sql.SqlFunction
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–2023 The Apache Software Foundation. All rights reserved.