Uses of Class
org.apache.flink.table.functions.FunctionKind
-
-
Uses of FunctionKind in org.apache.flink.table.expressions
Methods in org.apache.flink.table.expressions with parameters of type FunctionKind Modifier and Type Method Description static boolean
ApiExpressionUtils. isFunctionOfKind(Expression expression, FunctionKind kind)
Checks if the expression is a function call of given type. -
Uses of FunctionKind in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return FunctionKind Modifier and Type Method Description FunctionKind
AggregateFunction. getKind()
FunctionKind
AggregateFunctionDefinition. getKind()
Deprecated.FunctionKind
AsyncScalarFunction. getKind()
FunctionKind
AsyncTableFunction. getKind()
FunctionKind
BuiltInFunctionDefinition. getKind()
FunctionKind
DeclarativeAggregateFunction. getKind()
FunctionKind
FunctionDefinition. getKind()
Returns the kind of function this definition describes.FunctionKind
ScalarFunction. getKind()
FunctionKind
ScalarFunctionDefinition. getKind()
Deprecated.FunctionKind
TableAggregateFunction. getKind()
FunctionKind
TableAggregateFunctionDefinition. getKind()
Deprecated.FunctionKind
TableFunction. getKind()
FunctionKind
TableFunctionDefinition. getKind()
Deprecated.static FunctionKind
FunctionKind. valueOf(String name)
Returns the enum constant of this type with the specified name.static FunctionKind[]
FunctionKind. values()
Returns an array containing the constants of this enum type, in the order they are declared.Methods in org.apache.flink.table.functions with parameters of type FunctionKind Modifier and Type Method Description BuiltInFunctionDefinition.Builder
BuiltInFunctionDefinition.Builder. kind(FunctionKind kind)
-
Uses of FunctionKind in org.apache.flink.table.gateway.api.results
Methods in org.apache.flink.table.gateway.api.results that return types with arguments of type FunctionKind Modifier and Type Method Description Optional<FunctionKind>
FunctionInfo. getKind()
Constructors in org.apache.flink.table.gateway.api.results with parameters of type FunctionKind Constructor Description FunctionInfo(FunctionIdentifier identifier, FunctionKind kind)
-
Uses of FunctionKind in org.apache.flink.table.procedures
Methods in org.apache.flink.table.procedures that return FunctionKind Modifier and Type Method Description FunctionKind
ProcedureDefinition. getKind()
-
Uses of FunctionKind in org.apache.flink.table.runtime.functions
Methods in org.apache.flink.table.runtime.functions that return FunctionKind Modifier and Type Method Description FunctionKind
BuiltInSpecializedFunction. getKind()
-