Uses of Interface
org.apache.flink.table.functions.FunctionDefinition
-
-
Uses of FunctionDefinition in org.apache.flink.table.expressions
Methods in org.apache.flink.table.expressions that return FunctionDefinition Modifier and Type Method Description FunctionDefinition
AggregateExpression. getFunctionDefinition()
FunctionDefinition
CallExpression. getFunctionDefinition()
Methods in org.apache.flink.table.expressions with parameters of type FunctionDefinition Modifier and Type Method Description static CallExpression
CallExpression. anonymous(FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)
Creates aCallExpression
to an anonymous function that has been declared inline without aFunctionIdentifier
.static CallExpression
CallExpression. permanent(FunctionIdentifier functionIdentifier, FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)
static CallExpression
CallExpression. temporary(FunctionIdentifier functionIdentifier, FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)
Creates aCallExpression
to a temporary function (potentially shadowing aCatalog
function or providing a system function).Constructors in org.apache.flink.table.expressions with parameters of type FunctionDefinition Constructor Description AggregateExpression(FunctionDefinition functionDefinition, List<FieldReferenceExpression> args, CallExpression filterExpression, DataType resultType, boolean distinct, boolean approximate, boolean ignoreNulls)
CallExpression(boolean isTemporary, FunctionIdentifier functionIdentifier, FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)
-
Uses of FunctionDefinition in org.apache.flink.table.factories
Methods in org.apache.flink.table.factories that return FunctionDefinition Modifier and Type Method Description FunctionDefinition
FunctionDefinitionFactory. createFunctionDefinition(String name, CatalogFunction catalogFunction, FunctionDefinitionFactory.Context context)
Creates aFunctionDefinition
from givenCatalogFunction
with the givenFunctionDefinitionFactory.Context
containing the class loader of the current session, which is useful when it's needed to load class from class name. -
Uses of FunctionDefinition in org.apache.flink.table.functions
Subinterfaces of FunctionDefinition in org.apache.flink.table.functions Modifier and Type Interface Description interface
SpecializedFunction
AFunctionDefinition
that can provide a runtime implementation (i.e. the function's body) that is specialized for the given call and session.Classes in org.apache.flink.table.functions that implement FunctionDefinition Modifier and Type Class Description class
AggregateFunction<T,ACC>
Base class for a user-defined aggregate function.class
AggregateFunctionDefinition
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.class
AsyncLookupFunction
A wrapper class ofAsyncTableFunction
for asynchronously lookup rows matching the lookup keys from external system.class
AsyncScalarFunction
Base class for a user-defined scalar function which returns results asynchronously.class
AsyncTableFunction<T>
Base class for a user-defined asynchronous table function.class
BuiltInFunctionDefinition
Definition of a built-in function.class
ImperativeAggregateFunction<T,ACC>
Base class for user-definedAggregateFunction
andTableAggregateFunction
.class
LookupFunction
A wrapper class ofTableFunction
for synchronously lookup rows matching the lookup keys from external system.class
ProcessTableFunction<T>
Base class for a user-defined process table function.class
ScalarFunction
Base class for a user-defined scalar function.class
ScalarFunctionDefinition
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.class
TableAggregateFunction<T,ACC>
Base class for a user-defined table aggregate function.class
TableAggregateFunctionDefinition
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.class
TableFunction<T>
Base class for a user-defined table function.class
TableFunctionDefinition
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.class
TemporalTableFunction
Class representing temporal table function over some history table.class
UserDefinedFunction
Base class for all user-defined functions.Fields in org.apache.flink.table.functions with type parameters of type FunctionDefinition Modifier and Type Field Description static List<FunctionDefinition>
BuiltInFunctionDefinitions. ORDERING
static Set<FunctionDefinition>
BuiltInFunctionDefinitions. TIME_ATTRIBUTES
static Set<FunctionDefinition>
BuiltInFunctionDefinitions. WINDOW_PROPERTIES
Methods in org.apache.flink.table.functions with parameters of type FunctionDefinition Modifier and Type Method Description static UserDefinedFunction
UserDefinedFunctionHelper. createSpecializedFunction(String functionName, FunctionDefinition definition, CallContext callContext, ClassLoader builtInClassLoader, org.apache.flink.configuration.ReadableConfig configuration, SpecializedFunction.ExpressionEvaluatorFactory evaluatorFactory)
Creates the runtime implementation of aFunctionDefinition
as an instance ofUserDefinedFunction
. -
Uses of FunctionDefinition in org.apache.flink.table.functions.python
Classes in org.apache.flink.table.functions.python that implement FunctionDefinition Modifier and Type Class Description class
PythonAggregateFunction
The wrapper of user defined python aggregate function.class
PythonScalarFunction
The wrapper of user defined python scalar function.class
PythonTableAggregateFunction
The wrapper of user defined python table aggregate function.class
PythonTableFunction
The wrapper of user defined python table function. -
Uses of FunctionDefinition in org.apache.flink.table.module
Methods in org.apache.flink.table.module that return types with arguments of type FunctionDefinition Modifier and Type Method Description Optional<FunctionDefinition>
CoreModule. getFunctionDefinition(String name)
default Optional<FunctionDefinition>
Module. getFunctionDefinition(String name)
Get an optional ofFunctionDefinition
by a given name. -
Uses of FunctionDefinition in org.apache.flink.table.procedures
Classes in org.apache.flink.table.procedures that implement FunctionDefinition Modifier and Type Class Description class
ProcedureDefinition
Definition of a procedure. -
Uses of FunctionDefinition in org.apache.flink.table.types.inference
Methods in org.apache.flink.table.types.inference that return FunctionDefinition Modifier and Type Method Description FunctionDefinition
CallContext. getFunctionDefinition()
Returns the function definition that defines the function currently being called.Methods in org.apache.flink.table.types.inference with parameters of type FunctionDefinition Modifier and Type Method Description static String
TypeInferenceUtil. generateSignature(TypeInference typeInference, String name, FunctionDefinition definition)
Generates a signature of the givenFunctionDefinition
.Signature.Argument
ArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Returns a summary of the function's expected argument atargumentPos
.List<Signature>
InputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
Returns a summary of the function's expected signatures.static TypeInferenceUtil.SurroundingInfo
TypeInferenceUtil.SurroundingInfo. of(String name, FunctionDefinition functionDefinition, TypeInference typeInference, int argumentCount, int innerCallPosition, boolean isGroupedAggregation)
-
Uses of FunctionDefinition in org.apache.flink.table.types.inference.strategies
Methods in org.apache.flink.table.types.inference.strategies with parameters of type FunctionDefinition Modifier and Type Method Description Signature.Argument
AndArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
AnyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
ArrayComparableElementArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
ArrayOfStringArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
CommonArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
CompositeArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
ConstraintArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
ExplicitArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
FamilyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
IndexArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
ItemAtIndexArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
JsonQueryOnErrorEmptyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
LiteralArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
OrArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
OutputArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
PercentageArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
PercentageArrayArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
RootArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
SymbolArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
Signature.Argument
TypeLiteralArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)
List<Signature>
CommonCollectionInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
CommonInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
ComparableTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
LeadLagInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
OrInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
OverTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
ReinterpretCastInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
RepeatingSequenceInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
SequenceInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
SubQueryInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
SubsequenceInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
VaryingSequenceInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
WildcardInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
List<Signature>
WindowTimeIndictorInputTypeStrategy. getExpectedSignatures(FunctionDefinition definition)
-
Uses of FunctionDefinition in org.apache.flink.table.types.inference.utils
Methods in org.apache.flink.table.types.inference.utils that return FunctionDefinition Modifier and Type Method Description FunctionDefinition
AdaptedCallContext. getFunctionDefinition()
FunctionDefinition
UnknownCallContext. getFunctionDefinition()
Constructors in org.apache.flink.table.types.inference.utils with parameters of type FunctionDefinition Constructor Description UnknownCallContext(DataTypeFactory typeFactory, String name, FunctionDefinition functionDefinition, int argumentCount, boolean isGroupedAggregation)
-