Modifier and Type | Class and Description |
---|---|
class |
HBaseLookupFunction
The HBaseLookupFunction is a standard user-defined table function, it can be used in tableAPI and
also useful for temporal table join plan in SQL.
|
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 |
JdbcLookupFunction
A
TableFunction to query fields from JDBC by keys. |
class |
JdbcRowDataLookupFunction
A lookup function for
JdbcDynamicTableSource . |
Modifier and Type | Method and Description |
---|---|
static ApiExpression |
Expressions.call(UserDefinedFunction function,
Object... arguments)
A call to an unregistered, inline function.
|
void |
TableEnvironment.createTemporaryFunction(String path,
UserDefinedFunction functionInstance)
Registers a
UserDefinedFunction instance as a temporary catalog function. |
void |
TableEnvironment.createTemporarySystemFunction(String name,
UserDefinedFunction functionInstance)
Registers a
UserDefinedFunction instance as a temporary system function. |
Modifier and Type | Method and Description |
---|---|
static ApiExpression |
Expressions.call(Class<? extends UserDefinedFunction> function,
Object... arguments)
A call to an unregistered, inline function.
|
void |
TableEnvironment.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a catalog function in the given path. |
void |
TableEnvironment.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass,
boolean ignoreIfExists)
Registers a
UserDefinedFunction class as a catalog function in the given path. |
void |
TableEnvironment.createTemporaryFunction(String path,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a temporary catalog function. |
void |
TableEnvironment.createTemporarySystemFunction(String name,
Class<? extends UserDefinedFunction> functionClass)
Registers a
UserDefinedFunction class as a temporary system function. |
Modifier and Type | Method and Description |
---|---|
void |
TableEnvironmentImpl.createTemporaryFunction(String path,
UserDefinedFunction functionInstance) |
void |
TableEnvironmentImpl.createTemporarySystemFunction(String name,
UserDefinedFunction functionInstance) |
Modifier and Type | Method and Description |
---|---|
void |
TableEnvironmentImpl.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass) |
void |
TableEnvironmentImpl.createFunction(String path,
Class<? extends UserDefinedFunction> functionClass,
boolean ignoreIfExists) |
void |
TableEnvironmentImpl.createTemporaryFunction(String path,
Class<? extends UserDefinedFunction> functionClass) |
void |
TableEnvironmentImpl.createTemporarySystemFunction(String name,
Class<? extends UserDefinedFunction> functionClass) |
Modifier and Type | Method and Description |
---|---|
void |
FunctionCatalog.registerCatalogFunction(UnresolvedIdentifier unresolvedIdentifier,
Class<? extends UserDefinedFunction> functionClass,
boolean ignoreIfExists)
Registers a catalog function by also considering temporary catalog functions.
|
Modifier and Type | Class and Description |
---|---|
class |
FileSystemLookupFunction<T extends InputSplit>
Lookup table function for filesystem connector tables.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateFunction<T,ACC>
Base class for user-defined aggregates.
|
class |
AsyncTableFunction<T>
Base class for a user-defined asynchronously table function (UDTF).
|
class |
ScalarFunction
Base class for a user-defined scalar function.
|
class |
TableAggregateFunction<T,ACC>
Base class for user-defined table aggregates.
|
class |
TableFunction<T>
Base class for a user-defined table function.
|
class |
TemporalTableFunction
Class representing temporal table function over some history table.
|
class |
TemporalTableFunctionImpl
Class representing temporal table function over some history table.
|
class |
UserDefinedAggregateFunction<T,ACC>
Base class for user-defined aggregates and table aggregates.
|
Modifier and Type | Method and Description |
---|---|
static UserDefinedFunction |
FunctionService.createFunction(FunctionDescriptor descriptor)
Creates a user-defined function with the given properties and the current thread's context
class loader.
|
static UserDefinedFunction |
FunctionService.createFunction(FunctionDescriptor descriptor,
ClassLoader classLoader)
Creates a user-defined function with the given properties.
|
static UserDefinedFunction |
FunctionService.createFunction(FunctionDescriptor descriptor,
ClassLoader classLoader,
boolean performValidation)
Creates a user-defined function with the given properties.
|
static UserDefinedFunction |
FunctionService.createFunction(FunctionDescriptor descriptor,
ClassLoader classLoader,
boolean performValidation,
ReadableConfig config)
Creates a user-defined function with the given properties.
|
static UserDefinedFunction |
UserDefinedFunctionHelper.instantiateFunction(Class<? extends UserDefinedFunction> functionClass)
Instantiates a
UserDefinedFunction assuming a default constructor. |
Modifier and Type | Method and Description |
---|---|
static void |
UserDefinedFunctionHelper.prepareInstance(ReadableConfig config,
UserDefinedFunction function)
Prepares a
UserDefinedFunction instance for usage in the API. |
Modifier and Type | Method and Description |
---|---|
static UserDefinedFunction |
UserDefinedFunctionHelper.instantiateFunction(Class<? extends UserDefinedFunction> functionClass)
Instantiates a
UserDefinedFunction assuming a default constructor. |
static void |
UserDefinedFunctionHelper.validateClass(Class<? extends UserDefinedFunction> functionClass)
Validates a
UserDefinedFunction class for usage in the API. |
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 |
PythonScalarFunction
The wrapper of user defined python scalar function.
|
class |
PythonTableFunction
The wrapper of user defined python table function.
|
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 |
CollectAggFunction<T>
Aggregate function for COLLECT.
|
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 |
FirstValueAggFunction<T>
built-in FirstValue aggregate function.
|
static class |
FirstValueAggFunction.BooleanFirstValueAggFunction
Built-in Boolean FirstValue aggregate function.
|
static class |
FirstValueAggFunction.ByteFirstValueAggFunction
Built-in Byte FirstValue aggregate function.
|
static class |
FirstValueAggFunction.DecimalFirstValueAggFunction
Built-in DecimalData FirstValue aggregate function.
|
static class |
FirstValueAggFunction.DoubleFirstValueAggFunction
Built-in Double FirstValue aggregate function.
|
static class |
FirstValueAggFunction.FloatFirstValueAggFunction
Built-in Float FirstValue aggregate function.
|
static class |
FirstValueAggFunction.IntFirstValueAggFunction
Built-in Int FirstValue aggregate function.
|
static class |
FirstValueAggFunction.LongFirstValueAggFunction
Built-in Long FirstValue aggregate function.
|
static class |
FirstValueAggFunction.ShortFirstValueAggFunction
Built-in Short FirstValue aggregate function.
|
static class |
FirstValueAggFunction.StringFirstValueAggFunction
Built-in String FirstValue aggregate function.
|
class |
FirstValueWithRetractAggFunction<T>
built-in FirstValue with retraction aggregate function.
|
static class |
FirstValueWithRetractAggFunction.BooleanFirstValueWithRetractAggFunction
Built-in Boolean FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.ByteFirstValueWithRetractAggFunction
Built-in Byte FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.DecimalFirstValueWithRetractAggFunction
Built-in DecimalData FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.DoubleFirstValueWithRetractAggFunction
Built-in Double FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.FloatFirstValueWithRetractAggFunction
Built-in Float FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.IntFirstValueWithRetractAggFunction
Built-in Int FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.LongFirstValueWithRetractAggFunction
Built-in Long FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.ShortFirstValueWithRetractAggFunction
Built-in Short FirstValue with retract aggregate function.
|
static class |
FirstValueWithRetractAggFunction.StringFirstValueWithRetractAggFunction
Built-in String FirstValue with retract aggregate function.
|
class |
IncrSumAggFunction
built-in IncrSum aggregate function, negative number is discarded to ensure the monotonicity.
|
static class |
IncrSumAggFunction.ByteIncrSumAggFunction
Built-in Byte IncrSum aggregate function.
|
static class |
IncrSumAggFunction.DecimalIncrSumAggFunction
Built-in Decimal IncrSum aggregate function.
|
static class |
IncrSumAggFunction.DoubleIncrSumAggFunction
Built-in Double IncrSum aggregate function.
|
static class |
IncrSumAggFunction.FloatIncrSumAggFunction
Built-in Float IncrSum aggregate function.
|
static class |
IncrSumAggFunction.IntIncrSumAggFunction
Built-in Int IncrSum aggregate function.
|
static class |
IncrSumAggFunction.LongIncrSumAggFunction
Built-in Long IncrSum aggregate function.
|
static class |
IncrSumAggFunction.ShortIncrSumAggFunction
Built-in Short IncrSum aggregate function.
|
class |
IncrSumWithRetractAggFunction
built-in IncrSum with retract aggregate function, negative number is discarded to ensure the
monotonicity.
|
static class |
IncrSumWithRetractAggFunction.ByteIncrSumWithRetractAggFunction
Built-in Byte IncrSum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.DecimalIncrSumWithRetractAggFunction
Built-in Decimal IncrSum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.DoubleIncrSumWithRetractAggFunction
Built-in Double IncrSum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.FloatIncrSumWithRetractAggFunction
Built-in Float IncrSum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.IntIncrSumWithRetractAggFunction
Built-in IncrInt Sum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.LongIncrSumWithRetractAggFunction
Built-in Long IncrSum with retract aggregate function.
|
static class |
IncrSumWithRetractAggFunction.ShortIncrSumWithRetractAggFunction
Built-in Short IncrSum with retract aggregate function.
|
class |
LastValueAggFunction<T>
built-in LastValue aggregate function.
|
static class |
LastValueAggFunction.BooleanLastValueAggFunction
Built-in Boolean LastValue aggregate function.
|
static class |
LastValueAggFunction.ByteLastValueAggFunction
Built-in Byte LastValue aggregate function.
|
static class |
LastValueAggFunction.DecimalLastValueAggFunction
Built-in DecimalData LastValue aggregate function.
|
static class |
LastValueAggFunction.DoubleLastValueAggFunction
Built-in Double LastValue aggregate function.
|
static class |
LastValueAggFunction.FloatLastValueAggFunction
Built-in Float LastValue aggregate function.
|
static class |
LastValueAggFunction.IntLastValueAggFunction
Built-in Int LastValue aggregate function.
|
static class |
LastValueAggFunction.LongLastValueAggFunction
Built-in Long LastValue aggregate function.
|
static class |
LastValueAggFunction.ShortLastValueAggFunction
Built-in Short LastValue aggregate function.
|
static class |
LastValueAggFunction.StringLastValueAggFunction
Built-in String LastValue aggregate function.
|
class |
LastValueWithRetractAggFunction<T>
built-in LastValue with retraction aggregate function.
|
static class |
LastValueWithRetractAggFunction.BooleanLastValueWithRetractAggFunction
Built-in Boolean LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.ByteLastValueWithRetractAggFunction
Built-in Byte LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.DecimalLastValueWithRetractAggFunction
Built-in DecimalData LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.DoubleLastValueWithRetractAggFunction
Built-in Double LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.FloatLastValueWithRetractAggFunction
Built-in Float LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.IntLastValueWithRetractAggFunction
Built-in Int LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.LongLastValueWithRetractAggFunction
Built-in Long LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.ShortLastValueWithRetractAggFunction
Built-in Short LastValue with retract aggregate function.
|
static class |
LastValueWithRetractAggFunction.StringLastValueWithRetractAggFunction
Built-in String LastValue with retract 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.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 |
ListAggWithRetractAggFunction
built-in listagg with retraction aggregate function.
|
class |
ListAggWsWithRetractAggFunction
built-in listAggWs with retraction 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.TimestampMaxAggFunction
Built-in Timestamp Max aggregate function.
|
class |
MaxWithRetractAggFunction<T extends Comparable>
built-in Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.BooleanMaxWithRetractAggFunction
Built-in Boolean Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.ByteMaxWithRetractAggFunction
Built-in Byte Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.DateMaxWithRetractAggFunction
Built-in Date Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.DecimalMaxWithRetractAggFunction
Built-in Big Decimal Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.DoubleMaxWithRetractAggFunction
Built-in Double Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.FloatMaxWithRetractAggFunction
Built-in Float Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.IntMaxWithRetractAggFunction
Built-in Int Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.LongMaxWithRetractAggFunction
Built-in Long Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.ShortMaxWithRetractAggFunction
Built-in Short Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.StringMaxWithRetractAggFunction
Built-in String Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.TimeMaxWithRetractAggFunction
Built-in Time Max with retraction aggregate function.
|
static class |
MaxWithRetractAggFunction.TimestampMaxWithRetractAggFunction
Built-in Timestamp Max with retraction 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.TimestampMinAggFunction
Built-in Timestamp Min aggregate function.
|
class |
MinWithRetractAggFunction<T extends Comparable>
built-in Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.BooleanMinWithRetractAggFunction
Built-in Boolean Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.ByteMinWithRetractAggFunction
Built-in Byte Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.DateMinWithRetractAggFunction
Built-in Date Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.DecimalMinWithRetractAggFunction
Built-in Big DecimalData Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.DoubleMinWithRetractAggFunction
Built-in Double Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.FloatMinWithRetractAggFunction
Built-in Float Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.IntMinWithRetractAggFunction
Built-in Int Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.LongMinWithRetractAggFunction
Built-in Long Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.ShortMinWithRetractAggFunction
Built-in Short Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.StringMinWithRetractAggFunction
Built-in String Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.TimeMinWithRetractAggFunction
Built-in Time Min with retraction aggregate function.
|
static class |
MinWithRetractAggFunction.TimestampMinWithRetractAggFunction
Built-in Timestamp Min with retraction 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.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 | Class and Description |
---|---|
class |
ReplicateRows
Replicate the row N times.
|
Modifier and Type | Class and Description |
---|---|
static class |
CsvTableSource.CsvLookupFunction
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.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.