Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
AggregateExpression.getFunctionDefinition() |
FunctionDefinition |
CallExpression.getFunctionDefinition() |
Constructor and Description |
---|
AggregateExpression(FunctionDefinition functionDefinition,
List<FieldReferenceExpression> args,
CallExpression filterExpression,
DataType resultType,
boolean distinct,
boolean approximate,
boolean ignoreNulls) |
CallExpression(FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType) |
CallExpression(FunctionIdentifier functionIdentifier,
FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType) |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
FunctionDefinitionFactory.createFunctionDefinition(String name,
CatalogFunction catalogFunction)
Creates a
FunctionDefinition from given CatalogFunction . |
Modifier and Type | Interface and Description |
---|---|
interface |
SpecializedFunction
A
FunctionDefinition that can provide a runtime implementation (i.e. |
Modifier and Type | Class and Description |
---|---|
class |
AggregateFunction<T,ACC>
Base class for a user-defined aggregate function.
|
class |
AggregateFunctionDefinition
A "marker" function definition of an user-defined aggregate function that uses the old type
system stack.
|
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-defined
AggregateFunction and TableAggregateFunction . |
class |
ScalarFunction
Base class for a user-defined scalar function.
|
class |
ScalarFunctionDefinition
A "marker" function definition of a user-defined scalar function that uses the old type system
stack.
|
class |
TableAggregateFunction<T,ACC>
Base class for a user-defined table aggregate function.
|
class |
TableAggregateFunctionDefinition
A "marker" function definition of an user-defined table aggregate function that uses the old type
system stack.
|
class |
TableFunction<T>
Base class for a user-defined table function.
|
class |
TableFunctionDefinition
A "marker" function definition of an user-defined table function that uses the old type system
stack.
|
class |
TemporalTableFunction
Class representing temporal table function over some history table.
|
class |
UserDefinedFunction
Base class for all user-defined functions.
|
Modifier and Type | Field and Description |
---|---|
static List<FunctionDefinition> |
BuiltInFunctionDefinitions.ORDERING |
static Set<FunctionDefinition> |
BuiltInFunctionDefinitions.TIME_ATTRIBUTES |
static Set<FunctionDefinition> |
BuiltInFunctionDefinitions.WINDOW_PROPERTIES |
Modifier and Type | Method and Description |
---|---|
static UserDefinedFunction |
UserDefinedFunctionHelper.createSpecializedFunction(String functionName,
FunctionDefinition definition,
CallContext callContext,
ClassLoader builtInClassLoader,
org.apache.flink.configuration.ReadableConfig configuration)
Creates the runtime implementation of a
FunctionDefinition as an instance of UserDefinedFunction . |
Modifier and Type | Class and 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.
|
Modifier and Type | Method and Description |
---|---|
default Optional<FunctionDefinition> |
Module.getFunctionDefinition(String name)
Get an optional of
FunctionDefinition by a given name. |
Optional<FunctionDefinition> |
CoreModule.getFunctionDefinition(String name) |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
CallContext.getFunctionDefinition()
Returns the function definition that defines the function currently being called.
|
Modifier and Type | Method and Description |
---|---|
static String |
TypeInferenceUtil.generateSignature(TypeInference typeInference,
String name,
FunctionDefinition definition)
Generates a signature of the given
FunctionDefinition . |
Signature.Argument |
ArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos)
Returns a summary of the function's expected argument at
argumentPos . |
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) |
Modifier and Type | Method and Description |
---|---|
Signature.Argument |
CommonArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
RootArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
FamilyArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
ExplicitArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
TypeLiteralArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
LiteralArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
ConstraintArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
CompositeArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
OrArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
OutputArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
AndArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
AnyArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
SymbolArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
List<Signature> |
ComparableTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
SequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
OrInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
WildcardInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
CommonInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
VaryingSequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
SubsequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
AdaptedCallContext.getFunctionDefinition() |
FunctionDefinition |
UnknownCallContext.getFunctionDefinition() |
Constructor and Description |
---|
UnknownCallContext(DataTypeFactory typeFactory,
String name,
FunctionDefinition functionDefinition,
int argumentCount,
boolean isGroupedAggregation) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.