Package org.apache.flink.table.functions
-
Interface Summary Interface Description ChangelogFunction An extension that allows a process table function (PTF) to emit results with changelog semantics.ChangelogFunction.ChangelogContext Context during changelog mode inference.FunctionDefinition Definition of a function.ProcessTableFunction.Context Context that can be added as a first argument to the eval() method for additional information about the input tables and other services provided by the framework.ProcessTableFunction.OnTimerContext SpecialProcessTableFunction.Contextthat is available when theonTimer()method is called.ProcessTableFunction.TimeContext<TimeType> A context that gives access to Flink's concepts of time and timers.SpecializedFunction AFunctionDefinitionthat can provide a runtime implementation (i.e. the function's body) that is specialized for the given call and session.SpecializedFunction.ExpressionEvaluator Serializable factory that can be passed into aUserDefinedFunctionfor evaluating previously defined expression during runtime.SpecializedFunction.ExpressionEvaluatorFactory Helper interface for creatingSpecializedFunction.ExpressionEvaluators.SpecializedFunction.SpecializedContext Provides call and session information for the specialized function.SqlCallSyntax Provides a format for unparsingBuiltInFunctionDefinitionsinto a SQL string.TableAggregateFunction.RetractableCollector<T> Collects a record and forwards it.TableSemantics Provides call information about the table that has been passed to a table argument. -
Class Summary Class Description AggregateFunction<T,ACC> Base class for a user-defined aggregate function.AggregateFunctionDefinition Deprecated. Non-legacy functions can simply omit this wrapper for declarations.AsyncLookupFunction A wrapper class ofAsyncTableFunctionfor asynchronously lookup rows matching the lookup keys from external system.AsyncPredictFunction A wrapper class ofAsyncTableFunctionfor asynchronous model inference.AsyncScalarFunction Base class for a user-defined scalar function which returns results asynchronously.AsyncTableFunction<T> Base class for a user-defined asynchronous table function.BuiltInFunctionDefinition Definition of a built-in function.BuiltInFunctionDefinition.Builder Builder for fluent definition of built-in functions.BuiltInFunctionDefinitions Dictionary of function definitions for all built-in functions.FunctionContext AFunctionContextallows to obtain global runtime information about the context in which the user-defined function is executed.FunctionIdentifier Identifies a system function with function name or a catalog function with a fully qualified identifier.ImperativeAggregateFunction<T,ACC> Base class for user-definedAggregateFunctionandTableAggregateFunction.LegacyUserDefinedFunctionInference Deprecated. LookupFunction A wrapper class ofTableFunctionfor synchronously lookup rows matching the lookup keys from external system.PredictFunction A wrapper class ofTableFunctionfor synchronous model inference.ProcessTableFunction<T> Base class for a user-defined process table function (PTF).ScalarFunction Base class for a user-defined scalar function.ScalarFunctionDefinition Deprecated. Non-legacy functions can simply omit this wrapper for declarations.TableAggregateFunction<T,ACC> Base class for a user-defined table aggregate function.TableAggregateFunctionDefinition Deprecated. Non-legacy functions can simply omit this wrapper for declarations.TableFunction<T> Base class for a user-defined table function.TableFunctionDefinition Deprecated. Non-legacy functions can simply omit this wrapper for declarations.TemporalTableFunction Class representing temporal table function over some history table.UserDefinedFunction Base class for all user-defined functions.UserDefinedFunctionHelper Utility for dealing with subclasses ofUserDefinedFunction. -
Enum Summary Enum Description FunctionKind Categorizes the semantics of aFunctionDefinition.FunctionRequirement Characteristics that aFunctionDefinitionrequires.