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 FunctionDefinitionAggregateExpression. getFunctionDefinition()FunctionDefinitionCallExpression. getFunctionDefinition()Methods in org.apache.flink.table.expressions with parameters of type FunctionDefinition Modifier and Type Method Description static CallExpressionCallExpression. anonymous(FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)Creates aCallExpressionto an anonymous function that has been declared inline without aFunctionIdentifier.static CallExpressionCallExpression. permanent(FunctionIdentifier functionIdentifier, FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)StringDefaultSqlFactory. serializeInlineFunction(FunctionDefinition functionDefinition)StringSqlFactory. serializeInlineFunction(FunctionDefinition functionDefinition)Called when an inline function is serialized.static CallExpressionCallExpression. temporary(FunctionIdentifier functionIdentifier, FunctionDefinition functionDefinition, List<ResolvedExpression> args, DataType dataType)Creates aCallExpressionto a temporary function (potentially shadowing aCatalogfunction 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 FunctionDefinitionFunctionDefinitionFactory. createFunctionDefinition(String name, CatalogFunction catalogFunction, FunctionDefinitionFactory.Context context)Creates aFunctionDefinitionfrom givenCatalogFunctionwith the givenFunctionDefinitionFactory.Contextcontaining 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 interfaceChangelogFunctionAn extension that allows a process table function (PTF) to emit results with changelog semantics.interfaceSpecializedFunctionAFunctionDefinitionthat 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 classAggregateFunction<T,ACC>Base class for a user-defined aggregate function.classAggregateFunctionDefinitionDeprecated.Non-legacy functions can simply omit this wrapper for declarations.classAsyncLookupFunctionA wrapper class ofAsyncTableFunctionfor asynchronously lookup rows matching the lookup keys from external system.classAsyncPredictFunctionA wrapper class ofAsyncTableFunctionfor asynchronous model inference.classAsyncScalarFunctionBase class for a user-defined scalar function which returns results asynchronously.classAsyncTableFunction<T>Base class for a user-defined asynchronous table function.classBuiltInFunctionDefinitionDefinition of a built-in function.classImperativeAggregateFunction<T,ACC>Base class for user-definedAggregateFunctionandTableAggregateFunction.classLookupFunctionA wrapper class ofTableFunctionfor synchronously lookup rows matching the lookup keys from external system.classPredictFunctionA wrapper class ofTableFunctionfor synchronous model inference.classProcessTableFunction<T>Base class for a user-defined process table function (PTF).classScalarFunctionBase class for a user-defined scalar function.classScalarFunctionDefinitionDeprecated.Non-legacy functions can simply omit this wrapper for declarations.classTableAggregateFunction<T,ACC>Base class for a user-defined table aggregate function.classTableAggregateFunctionDefinitionDeprecated.Non-legacy functions can simply omit this wrapper for declarations.classTableFunction<T>Base class for a user-defined table function.classTableFunctionDefinitionDeprecated.Non-legacy functions can simply omit this wrapper for declarations.classTemporalTableFunctionClass representing temporal table function over some history table.classUserDefinedFunctionBase 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. ORDERINGstatic Set<FunctionDefinition>BuiltInFunctionDefinitions. TIME_ATTRIBUTESstatic Set<FunctionDefinition>BuiltInFunctionDefinitions. WINDOW_PROPERTIESMethods in org.apache.flink.table.functions with parameters of type FunctionDefinition Modifier and Type Method Description static UserDefinedFunctionUserDefinedFunctionHelper. createSpecializedFunction(String functionName, FunctionDefinition definition, CallContext callContext, ClassLoader builtInClassLoader, org.apache.flink.configuration.ReadableConfig configuration, SpecializedFunction.ExpressionEvaluatorFactory evaluatorFactory)Creates the runtime implementation of aFunctionDefinitionas 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 classPythonAggregateFunctionThe wrapper of user defined python aggregate function.classPythonScalarFunctionThe wrapper of user defined python scalar function.classPythonTableAggregateFunctionThe wrapper of user defined python table aggregate function.classPythonTableFunctionThe 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 ofFunctionDefinitionby 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 classProcedureDefinitionDefinition 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 FunctionDefinitionCallContext. 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 StringTypeInferenceUtil. generateSignature(TypeInference typeInference, String name, FunctionDefinition definition)Generates a signature of the givenFunctionDefinition.Signature.ArgumentArgumentTypeStrategy. 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.SurroundingInfoTypeInferenceUtil.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.ArgumentAndArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentAnyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentArrayComparableElementArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentArrayOfStringArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentCommonArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentCompositeArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentConstraintArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentExplicitArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentFamilyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentIndexArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentItemAtIndexArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentJsonQueryOnErrorEmptyArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentLiteralArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentOrArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentOutputArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentPercentageArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentPercentageArrayArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentRootArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentSymbolArgumentTypeStrategy. getExpectedArgument(FunctionDefinition functionDefinition, int argumentPos)Signature.ArgumentTypeLiteralArgumentTypeStrategy. 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 FunctionDefinitionCastCallContext. getFunctionDefinition()FunctionDefinitionUnknownCallContext. 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)
-