Modifier and Type | Class and Description |
---|---|
class |
HBaseRowDataLookupFunction
The HBaseRowDataLookupFunction is a standard user-defined table function, it can be used in
tableAPI and also useful for temporal table join plan in SQL.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseRowDataAsyncLookupFunction
The HBaseRowDataAsyncLookupFunction is an implementation to lookup HBase data by rowkey in async
fashion.
|
Modifier and Type | Class and Description |
---|---|
class |
JdbcRowDataLookupFunction
A lookup function for
JdbcDynamicTableSource . |
Modifier and Type | Class and Description |
---|---|
class |
FileSystemLookupFunction<P>
Lookup function for filesystem connector tables.
|
Modifier and Type | Class and Description |
---|---|
class |
AddOne
Scala UDF for testing.
|
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
FunctionCatalog.InlineCatalogFunction.getDefinition() |
FunctionDefinition |
ContextResolvedFunction.getDefinition() |
Modifier and Type | Method and Description |
---|---|
static ContextResolvedFunction |
ContextResolvedFunction.anonymous(FunctionDefinition functionDefinition) |
static ContextResolvedFunction |
ContextResolvedFunction.permanent(FunctionIdentifier functionIdentifier,
FunctionDefinition functionDefinition) |
void |
FunctionCatalog.registerTemporaryCatalogFunction(UnresolvedIdentifier unresolvedIdentifier,
FunctionDefinition definition,
boolean ignoreIfExists)
Registers a temporary catalog function.
|
void |
FunctionCatalog.registerTemporarySystemFunction(String name,
FunctionDefinition definition,
boolean ignoreIfExists)
Registers a temporary system function.
|
static ContextResolvedFunction |
ContextResolvedFunction.temporary(FunctionIdentifier functionIdentifier,
FunctionDefinition functionDefinition) |
Constructor and Description |
---|
InlineCatalogFunction(FunctionDefinition definition) |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
HiveFunctionDefinitionFactory.createFunctionDefinition(String name,
CatalogFunction catalogFunction) |
FunctionDefinition |
HiveFunctionDefinitionFactory.createFunctionDefinitionFromFlinkFunction(String name,
CatalogFunction catalogFunction) |
FunctionDefinition |
HiveFunctionDefinitionFactory.createFunctionDefinitionFromHiveFunction(String name,
String functionClassName)
Create a FunctionDefinition from a Hive function's class name.
|
Modifier and Type | Class and Description |
---|---|
static class |
GettingStartedExample.AddressNormalizer
We can put frequently used procedures in user-defined functions.
|
Modifier and Type | Class and Description |
---|---|
class |
InternalRowMergerFunction
Merges two rows into a single row with unique field names.
|
class |
LastDatedValueFunction<T>
Implementation of an
AggregateFunction that returns a row containing the latest non-null
value with its corresponding date. |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
UnresolvedCallExpression.getFunctionDefinition() |
FunctionDefinition |
AggregateExpression.getFunctionDefinition() |
FunctionDefinition |
CallExpression.getFunctionDefinition() |
Modifier and Type | Method and Description |
---|---|
static CallExpression |
CallExpression.anonymous(FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType)
Creates a
CallExpression to an anonymous function that has been declared inline
without a FunctionIdentifier . |
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 a
CallExpression to a temporary function (potentially shadowing a Catalog function or providing a system function). |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(FunctionDefinition functionDefinition,
Expression... args) |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(FunctionDefinition functionDefinition,
List<Expression> args) |
Constructor and 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) |
CallExpression(FunctionDefinition functionDefinition,
List<ResolvedExpression> args,
DataType dataType)
Deprecated.
|
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
Deprecated.
Non-legacy functions can simply omit this wrapper for declarations.
|
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
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 |
TemporalTableFunctionImpl
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,
ReadableConfig configuration)
Creates the runtime implementation of a
FunctionDefinition as an instance of UserDefinedFunction . |
Modifier and Type | Class and Description |
---|---|
class |
HiveGenericUDAF
|
class |
HiveGenericUDF
A ScalarFunction implementation that calls Hive's
GenericUDF . |
class |
HiveGenericUDTF
A TableFunction implementation that calls Hive's
GenericUDTF . |
class |
HiveScalarFunction<UDFType>
Abstract class to provide more information for Hive
UDF and GenericUDF functions. |
class |
HiveSimpleUDF
A ScalarFunction implementation that calls Hive's
UDF . |
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 |
---|---|
Optional<FunctionDefinition> |
ModuleManager.getFunctionDefinition(String name)
Get an optional of
FunctionDefinition by a given name. |
Optional<FunctionDefinition> |
CoreModule.getFunctionDefinition(String name) |
default Optional<FunctionDefinition> |
Module.getFunctionDefinition(String name)
Get an optional of
FunctionDefinition by a given name. |
Modifier and Type | Method and Description |
---|---|
Optional<FunctionDefinition> |
HiveModule.getFunctionDefinition(String name) |
Constructor and Description |
---|
CreateTempSystemFunctionOperation(String functionName,
boolean ignoreIfExists,
FunctionDefinition functionDefinition) |
Modifier and Type | Method and Description |
---|---|
static UnresolvedCallExpression |
ExpressionBuilder.call(FunctionDefinition functionDefinition,
Expression... args) |
static UnresolvedCallExpression |
ExpressionBuilder.call(FunctionDefinition functionDefinition,
List<Expression> args) |
Modifier and Type | Method and Description |
---|---|
Optional<CustomizedConverter> |
CustomizedConverters.getConverter(FunctionDefinition functionDefinition) |
Modifier and Type | Class and Description |
---|---|
class |
AvgAggFunction
built-in avg aggregate function.
|
static class |
AvgAggFunction.ByteAvgAggFunction
Built-in Byte Avg aggregate function.
|
static class |
AvgAggFunction.DecimalAvgAggFunction
Built-in Decimal Avg aggregate function.
|
static class |
AvgAggFunction.DoubleAvgAggFunction
Built-in Double Avg aggregate function.
|
static class |
AvgAggFunction.FloatAvgAggFunction
Built-in Float Avg aggregate function.
|
static class |
AvgAggFunction.IntAvgAggFunction
Built-in Integer Avg aggregate function.
|
static class |
AvgAggFunction.LongAvgAggFunction
Built-in Long Avg aggregate function.
|
static class |
AvgAggFunction.ShortAvgAggFunction
Built-in Short Avg aggregate function.
|
class |
Count1AggFunction
This count1 aggregate function returns the count1 of values which go into it like
[[CountAggFunction]].
|
class |
CountAggFunction
built-in count aggregate function.
|
class |
DeclarativeAggregateFunction
API for aggregation functions that are expressed in terms of expressions.
|
class |
DenseRankAggFunction
built-in dense_rank aggregate function.
|
class |
LeadLagAggFunction
LEAD and LAG aggregate functions return the value of given expression evaluated at given offset.
|
static class |
LeadLagAggFunction.BooleanLeadLagAggFunction
BooleanLeadLagAggFunction.
|
static class |
LeadLagAggFunction.ByteLeadLagAggFunction
ByteLeadLagAggFunction.
|
static class |
LeadLagAggFunction.CharLeadLagAggFunction
CharLeadLagAggFunction.
|
static class |
LeadLagAggFunction.DateLeadLagAggFunction
DateLeadLagAggFunction.
|
static class |
LeadLagAggFunction.DecimalLeadLagAggFunction
DecimalLeadLagAggFunction.
|
static class |
LeadLagAggFunction.DoubleLeadLagAggFunction
DoubleLeadLagAggFunction.
|
static class |
LeadLagAggFunction.FloatLeadLagAggFunction
FloatLeadLagAggFunction.
|
static class |
LeadLagAggFunction.IntLeadLagAggFunction
IntLeadLagAggFunction.
|
static class |
LeadLagAggFunction.LongLeadLagAggFunction
LongLeadLagAggFunction.
|
static class |
LeadLagAggFunction.ShortLeadLagAggFunction
ShortLeadLagAggFunction.
|
static class |
LeadLagAggFunction.StringLeadLagAggFunction
StringLeadLagAggFunction.
|
static class |
LeadLagAggFunction.TimeLeadLagAggFunction
TimeLeadLagAggFunction.
|
static class |
LeadLagAggFunction.TimestampLeadLagAggFunction
TimestampLeadLagAggFunction.
|
class |
ListAggFunction
built-in listagg aggregate function.
|
class |
MaxAggFunction
built-in max aggregate function.
|
static class |
MaxAggFunction.BooleanMaxAggFunction
Built-in Boolean Max aggregate function.
|
static class |
MaxAggFunction.ByteMaxAggFunction
Built-in Byte Max aggregate function.
|
static class |
MaxAggFunction.DateMaxAggFunction
Built-in Date Max aggregate function.
|
static class |
MaxAggFunction.DecimalMaxAggFunction
Built-in Decimal Max aggregate function.
|
static class |
MaxAggFunction.DoubleMaxAggFunction
Built-in Double Max aggregate function.
|
static class |
MaxAggFunction.FloatMaxAggFunction
Built-in Float Max aggregate function.
|
static class |
MaxAggFunction.IntMaxAggFunction
Built-in Int Max aggregate function.
|
static class |
MaxAggFunction.LongMaxAggFunction
Built-in Long Max aggregate function.
|
static class |
MaxAggFunction.ShortMaxAggFunction
Built-in Short Max aggregate function.
|
static class |
MaxAggFunction.StringMaxAggFunction
Built-in String Max aggregate function.
|
static class |
MaxAggFunction.TimeMaxAggFunction
Built-in Time Max aggregate function.
|
static class |
MaxAggFunction.TimestampLtzMaxAggFunction
Built-in TimestampLtz Max aggregate function.
|
static class |
MaxAggFunction.TimestampMaxAggFunction
Built-in Timestamp Max aggregate function.
|
class |
MinAggFunction
built-in min aggregate function.
|
static class |
MinAggFunction.BooleanMinAggFunction
Built-in Boolean Min aggregate function.
|
static class |
MinAggFunction.ByteMinAggFunction
Built-in Byte Min aggregate function.
|
static class |
MinAggFunction.DateMinAggFunction
Built-in Date Min aggregate function.
|
static class |
MinAggFunction.DecimalMinAggFunction
Built-in Decimal Min aggregate function.
|
static class |
MinAggFunction.DoubleMinAggFunction
Built-in Double Min aggregate function.
|
static class |
MinAggFunction.FloatMinAggFunction
Built-in Float Min aggregate function.
|
static class |
MinAggFunction.IntMinAggFunction
Built-in Int Min aggregate function.
|
static class |
MinAggFunction.LongMinAggFunction
Built-in Long Min aggregate function.
|
static class |
MinAggFunction.ShortMinAggFunction
Built-in Short Min aggregate function.
|
static class |
MinAggFunction.StringMinAggFunction
Built-in String Min aggregate function.
|
static class |
MinAggFunction.TimeMinAggFunction
Built-in Time Min aggregate function.
|
static class |
MinAggFunction.TimestampLtzMinAggFunction
Built-in TimestampLtz Min aggregate function.
|
static class |
MinAggFunction.TimestampMinAggFunction
Built-in Timestamp Min aggregate function.
|
class |
RankAggFunction
built-in rank aggregate function.
|
class |
RankLikeAggFunctionBase
built-in rank like aggregate function, e.g.
|
class |
RowNumberAggFunction
built-in row_number aggregate function.
|
class |
SingleValueAggFunction
Base class for built-in single value aggregate function.
|
static class |
SingleValueAggFunction.BooleanSingleValueAggFunction
Built-in boolean single value aggregate function.
|
static class |
SingleValueAggFunction.ByteSingleValueAggFunction
Built-in byte single value aggregate function.
|
static class |
SingleValueAggFunction.DateSingleValueAggFunction
Built-in date single value aggregate function.
|
static class |
SingleValueAggFunction.DecimalSingleValueAggFunction
Built-in decimal single value aggregate function.
|
static class |
SingleValueAggFunction.DoubleSingleValueAggFunction
Built-in double single value aggregate function.
|
static class |
SingleValueAggFunction.FloatSingleValueAggFunction
Built-in float single value aggregate function.
|
static class |
SingleValueAggFunction.IntSingleValueAggFunction
Built-in int single value aggregate function.
|
static class |
SingleValueAggFunction.LongSingleValueAggFunction
Built-in long single value aggregate function.
|
static class |
SingleValueAggFunction.ShortSingleValueAggFunction
Built-in short single value aggregate function.
|
static class |
SingleValueAggFunction.StringSingleValueAggFunction
Built-in string single value aggregate function.
|
static class |
SingleValueAggFunction.TimeSingleValueAggFunction
Built-in time single value aggregate function.
|
static class |
SingleValueAggFunction.TimestampLtzSingleValueAggFunction
Built-in timestampLtz single value aggregate function.
|
static class |
SingleValueAggFunction.TimestampSingleValueAggFunction
Built-in timestamp single value aggregate function.
|
class |
Sum0AggFunction
built-in sum0 aggregate function.
|
static class |
Sum0AggFunction.ByteSum0AggFunction
Built-in Byte Sum0 aggregate function.
|
static class |
Sum0AggFunction.DecimalSum0AggFunction
Built-in Decimal Sum0 aggregate function.
|
static class |
Sum0AggFunction.DoubleSum0AggFunction
Built-in Double Sum0 aggregate function.
|
static class |
Sum0AggFunction.FloatSum0AggFunction
Built-in Float Sum0 aggregate function.
|
static class |
Sum0AggFunction.IntSum0AggFunction
Built-in Int Sum0 aggregate function.
|
static class |
Sum0AggFunction.LongSum0AggFunction
Built-in Long Sum0 aggregate function.
|
static class |
Sum0AggFunction.ShortSum0AggFunction
Built-in Short Sum0 aggregate function.
|
class |
SumAggFunction
built-in sum aggregate function.
|
static class |
SumAggFunction.ByteSumAggFunction
Built-in Byte Sum aggregate function.
|
static class |
SumAggFunction.DecimalSumAggFunction
Built-in Decimal Sum aggregate function.
|
static class |
SumAggFunction.DoubleSumAggFunction
Built-in Double Sum aggregate function.
|
static class |
SumAggFunction.FloatSumAggFunction
Built-in Float Sum aggregate function.
|
static class |
SumAggFunction.IntSumAggFunction
Built-in Int Sum aggregate function.
|
static class |
SumAggFunction.LongSumAggFunction
Built-in Long Sum aggregate function.
|
static class |
SumAggFunction.ShortSumAggFunction
Built-in Short Sum aggregate function.
|
class |
SumWithRetractAggFunction
built-in sum aggregate function with retraction.
|
static class |
SumWithRetractAggFunction.ByteSumWithRetractAggFunction
Built-in Byte Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.DecimalSumWithRetractAggFunction
Built-in Decimal Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.DoubleSumWithRetractAggFunction
Built-in Double Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.FloatSumWithRetractAggFunction
Built-in Float Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.IntSumWithRetractAggFunction
Built-in Int Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.LongSumWithRetractAggFunction
Built-in Long Sum with retract aggregate function.
|
static class |
SumWithRetractAggFunction.ShortSumWithRetractAggFunction
Built-in Short Sum with retract aggregate function.
|
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
BridgingSqlAggFunction.getDefinition() |
FunctionDefinition |
BridgingSqlFunction.getDefinition() |
Modifier and Type | Method and Description |
---|---|
FunctionDefinition |
AbstractSqlCallContext.getFunctionDefinition() |
Constructor and Description |
---|
AbstractSqlCallContext(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
String name,
boolean isGroupedAggregation) |
CallBindingCallContext(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
org.apache.calcite.sql.SqlCallBinding binding,
org.apache.calcite.rel.type.RelDataType outputType) |
OperatorBindingCallContext(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
org.apache.calcite.sql.SqlOperatorBinding binding,
org.apache.calcite.rel.type.RelDataType returnRelDataType) |
TypeInferenceOperandChecker(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
TypeInference typeInference) |
TypeInferenceOperandInference(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
TypeInference typeInference) |
TypeInferenceReturnInference(DataTypeFactory dataTypeFactory,
FunctionDefinition definition,
TypeInference typeInference) |
Modifier and Type | Method and Description |
---|---|
static FunctionDefinition |
ShortcutUtils.unwrapFunctionDefinition(ResolvedExpression expression) |
static FunctionDefinition |
ShortcutUtils.unwrapFunctionDefinition(org.apache.calcite.rex.RexNode rexNode) |
Modifier and Type | Class and Description |
---|---|
class |
BuiltInSpecializedFunction
Base class for built-in functions that need another level of specialization via
SpecializedFunction.specialize(SpecializedContext) . |
Modifier and Type | Class and Description |
---|---|
class |
BuiltInAggregateFunction<T,ACC>
Base class for runtime implementation represented as
AggregateFunction that is
constructed from SpecializedFunction.specialize(SpecializedContext) . |
class |
CollectAggFunction<T>
Built-in COLLECT aggregate function.
|
class |
FirstValueAggFunction<T>
Built-in FIRST_VALUE aggregate function.
|
class |
FirstValueWithRetractAggFunction<T>
Built-in FIRST_VALUE with retraction aggregate function.
|
class |
JsonArrayAggFunction
|
class |
JsonObjectAggFunction
|
class |
LagAggFunction<T>
Lag
AggregateFunction . |
class |
LastValueAggFunction<T>
Built-in LAST_VALUE aggregate function.
|
class |
LastValueWithRetractAggFunction<T>
Built-in LAST_VALUE with retraction aggregate function.
|
class |
ListAggWithRetractAggFunction
Built-in LISTAGG with retraction aggregate function.
|
class |
ListAggWsWithRetractAggFunction
Built-in LISTAGGWS with retraction aggregate function.
|
class |
MaxWithRetractAggFunction<T extends Comparable<T>>
Built-in MAX with retraction aggregate function.
|
class |
MinWithRetractAggFunction<T extends Comparable<T>>
Built-in MIN with retraction aggregate function.
|
Modifier and Type | Class and Description |
---|---|
class |
BuiltInScalarFunction
Base class for runtime implementation represented as
ScalarFunction that is constructed
from SpecializedFunction.specialize(SpecializedContext) . |
class |
CoalesceFunction
Implementation of
BuiltInFunctionDefinitions.COALESCE . |
class |
IfNullFunction
Implementation of
BuiltInFunctionDefinitions.IF_NULL . |
class |
SourceWatermarkFunction
Implementation of
BuiltInFunctionDefinitions.SOURCE_WATERMARK . |
class |
TypeOfFunction
Implementation of
BuiltInFunctionDefinitions.TYPE_OF . |
Modifier and Type | Class and Description |
---|---|
class |
BuiltInTableFunction<T>
Base class for runtime implementation represented as
TableFunction that is constructed
from SpecializedFunction.specialize(SpecializedContext) . |
class |
ReplicateRowsFunction
Replicate the row N times.
|
class |
UnnestRowsFunction
Flattens ARRAY, MAP, and MULTISET using a table function.
|
static class |
UnnestRowsFunction.CollectionUnnestTableFunction
Table function that unwraps the elements of a collection (array or multiset).
|
static class |
UnnestRowsFunction.MapUnnestTableFunction
Table function that unwraps the elements of a map.
|
Modifier and Type | Class and Description |
---|---|
static class |
CsvTableSource.CsvLookupFunction
Deprecated.
LookupFunction to support lookup in CsvTableSource.
|
Modifier and Type | Class and Description |
---|---|
class |
StringRegexReplaceFunction
Scalar function for replacing all occurrences of a regular expression with a replacement string.
|
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 |
AndArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
RootArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
OrArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
TypeLiteralArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
AnyArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
CommonArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
ConstraintArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
CompositeArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
ExplicitArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
SymbolArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
LiteralArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
OutputArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
Signature.Argument |
FamilyArgumentTypeStrategy.getExpectedArgument(FunctionDefinition functionDefinition,
int argumentPos) |
List<Signature> |
SubsequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
SequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
CommonInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
ComparableTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
RepeatingSequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
OrInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
VaryingSequenceInputTypeStrategy.getExpectedSignatures(FunctionDefinition definition) |
List<Signature> |
WildcardInputTypeStrategy.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–2023 The Apache Software Foundation. All rights reserved.