Class BridgingSqlAggFunction

  • All Implemented Interfaces:
    org.apache.calcite.plan.Context, org.apache.calcite.schema.Wrapper

    @Internal
    public final class BridgingSqlAggFunction
    extends org.apache.calcite.sql.SqlAggFunction
    Bridges FunctionDefinition to Calcite's representation of an aggregating function (either a system or user-defined function).
    • Field Summary

      • Fields inherited from class org.apache.calcite.sql.SqlOperator

        kind, MDX_PRECEDENCE, NL
    • Method Summary

      All Methods Static Methods Instance Methods Concrete Methods 
      Modifier and Type Method 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.
      • Methods inherited from class org.apache.calcite.sql.SqlAggFunction

        allowsFilter, allowsNullTreatment, getDistinctOptionality, getParameterTypes, getReturnType, getRollup, isAggregator, isPercentile, isQuantifierAllowed, requiresGroupOrder, requiresOrder, requiresOver, unwrap, validateCall
      • Methods inherited from class org.apache.calcite.sql.SqlFunction

        deriveType, getFunctionType, getNameAsId, getSqlIdentifier, getSyntax, unparse, 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, equals, getAllowedSignatures, getAllowedSignatures, getKind, getLeftPrec, getMonotonicity, getMonotonicity, getName, getOperandCountRange, getOperandTypeChecker, getOperandTypeInference, getReturnTypeInference, getRightPrec, getSignatureTemplate, getStrongPolicyInference, hashCode, inferReturnType, inferReturnType, isDynamicFunction, isGroup, isGroupAuxiliary, isName, isSymmetrical, leftPrec, not, preValidateCall, requiresDecimalExpansion, reverse, rewriteCall, rightPrec, toString, unparseListClause, unparseListClause, validateOperands, validRexOperands
      • Methods inherited from interface org.apache.calcite.schema.Wrapper

        maybeUnwrap, unwrapOrThrow
    • Method Detail

      • of

        public 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).
        Parameters:
        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 context
        typeInference - type inference logic
      • of

        public 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.
      • getTypeFactory

        public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
      • getParamTypes

        public List<org.apache.calcite.rel.type.RelDataType> getParamTypes()
        Overrides:
        getParamTypes in class org.apache.calcite.sql.SqlFunction
      • getParamNames

        public List<String> getParamNames()
        Overrides:
        getParamNames in class org.apache.calcite.sql.SqlFunction
      • isDeterministic

        public boolean isDeterministic()
        Overrides:
        isDeterministic in class org.apache.calcite.sql.SqlOperator