Uses of Package
org.apache.flink.table.functions
-
Classes in org.apache.flink.table.functions used by org.apache.flink.table.connector.source.lookup Class Description AsyncLookupFunction A wrapper class ofAsyncTableFunctionfor asynchronously lookup rows matching the lookup keys from external system.LookupFunction A wrapper class ofTableFunctionfor synchronously lookup rows matching the lookup keys from external system. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.expressions Class Description BuiltInFunctionDefinition Definition of a built-in function.FunctionDefinition Definition of a function.FunctionIdentifier Identifies a system function with function name or a catalog function with a fully qualified identifier. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.factories Class Description FunctionDefinition Definition of a function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.functions Class Description AggregateFunction Base class for a user-defined aggregate function.AsyncTableFunction 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.ChangelogFunction.ChangelogContext Context during changelog mode inference.FunctionContext AFunctionContextallows to obtain global runtime information about the context in which the user-defined function is executed.FunctionDefinition Definition of a function.FunctionIdentifier Identifies a system function with function name or a catalog function with a fully qualified identifier.FunctionKind Categorizes the semantics of aFunctionDefinition.FunctionRequirement Characteristics that aFunctionDefinitionrequires.ImperativeAggregateFunction Base class for user-definedAggregateFunctionandTableAggregateFunction.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.TimeContext A context that gives access to Flink's concepts of time and timers.ScalarFunction Base class for a user-defined scalar function.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 Base class for a user-defined table aggregate function.TableFunction Base class for a user-defined table function.TableSemantics Provides call information about the table that has been passed to a table argument.UserDefinedFunction Base class for all user-defined functions. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.functions.python Class Description AggregateFunction Base class for a user-defined aggregate function.FunctionDefinition Definition of a function.ImperativeAggregateFunction Base class for user-definedAggregateFunctionandTableAggregateFunction.ScalarFunction Base class for a user-defined scalar function.TableAggregateFunction Base class for a user-defined table aggregate function.TableFunction Base class for a user-defined table function.UserDefinedFunction Base class for all user-defined functions. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.legacy.connector.source Class Description AsyncTableFunction Base class for a user-defined asynchronous table function.TableFunction Base class for a user-defined table function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.legacy.sources Class Description AsyncTableFunction Base class for a user-defined asynchronous table function.TableFunction Base class for a user-defined table function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.ml Class Description AsyncPredictFunction A wrapper class ofAsyncTableFunctionfor asynchronous model inference.PredictFunction A wrapper class ofTableFunctionfor synchronous model inference. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.module Class Description FunctionDefinition Definition of a function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.procedures Class Description FunctionDefinition Definition of a function.FunctionKind Categorizes the semantics of aFunctionDefinition. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.types.extraction Class Description AggregateFunction Base class for a user-defined aggregate function.AsyncScalarFunction Base class for a user-defined scalar function which returns results asynchronously.AsyncTableFunction Base class for a user-defined asynchronous table function.ProcessTableFunction Base class for a user-defined process table function (PTF).ScalarFunction Base class for a user-defined scalar function.TableAggregateFunction Base class for a user-defined table aggregate function.TableFunction Base class for a user-defined table function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.types.inference Class Description FunctionDefinition Definition of a function.FunctionKind Categorizes the semantics of aFunctionDefinition.TableSemantics Provides call information about the table that has been passed to a table argument. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.types.inference.strategies Class Description FunctionDefinition Definition of a function. -
Classes in org.apache.flink.table.functions used by org.apache.flink.table.types.inference.utils Class Description FunctionDefinition Definition of a function.TableSemantics Provides call information about the table that has been passed to a table argument.