Modifier and Type | Method and Description |
---|---|
List<CatalogPartitionSpec> |
AbstractJdbcCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters) |
Modifier and Type | Method and Description |
---|---|
static OrcFilters.Predicate |
OrcFilters.toOrcPredicate(Expression expression) |
Modifier and Type | Class and Description |
---|---|
class |
ApiExpression
Java API class that gives access to expression operations.
|
Modifier and Type | Method and Description |
---|---|
Expression |
GroupWindow.getAlias() |
Expression |
OverWindow.getAlias() |
Expression |
Schema.UnresolvedComputedColumn.getExpression() |
Expression |
SessionWithGapOnTimeWithAlias.getGap() |
Expression |
OverWindow.getOrder() |
Expression |
OverWindow.getPreceding() |
Expression |
SlideWithSizeAndSlideOnTimeWithAlias.getSize() |
Expression |
TumbleWithSizeOnTimeWithAlias.getSize() |
Expression |
SlideWithSizeAndSlideOnTimeWithAlias.getSlide() |
Expression |
GroupWindow.getTimeField() |
Expression |
Schema.UnresolvedWatermarkSpec.getWatermarkExpression() |
Expression |
ApiExpression.toExpr() |
Modifier and Type | Method and Description |
---|---|
List<Expression> |
ApiExpression.getChildren() |
Optional<Expression> |
OverWindow.getFollowing() |
List<Expression> |
OverWindow.getPartitioning() |
Modifier and Type | Method and Description |
---|---|
Table |
Table.addColumns(Expression... fields)
Adds additional columns.
|
Table |
Table.addOrReplaceColumns(Expression... fields)
Adds additional columns.
|
AggregatedTable |
Table.aggregate(Expression aggregateFunction)
Performs a global aggregate operation with an aggregate function.
|
AggregatedTable |
WindowGroupedTable.aggregate(Expression aggregateFunction)
Performs an aggregate operation on a window grouped table.
|
AggregatedTable |
GroupedTable.aggregate(Expression aggregateFunction)
Performs an aggregate operation with an aggregate function.
|
Table |
Table.as(Expression... fields)
Deprecated.
|
OverWindow |
OverWindowPartitionedOrderedPreceding.as(Expression alias)
Assigns an alias for this window that the following
select() clause can refer to. |
SlideWithSizeAndSlideOnTimeWithAlias |
SlideWithSizeAndSlideOnTime.as(Expression alias)
Assigns an alias for this window that the following
groupBy() and select()
clause can refer to. |
OverWindow |
OverWindowPartitionedOrdered.as(Expression alias)
Assigns an alias for this window that the following
select() clause can refer to. |
TumbleWithSizeOnTimeWithAlias |
TumbleWithSizeOnTime.as(Expression alias)
Assigns an alias for this window that the following
groupBy() and select()
clause can refer to. |
SessionWithGapOnTimeWithAlias |
SessionWithGapOnTime.as(Expression alias)
Assigns an alias for this window that the following
groupBy() and select()
clause can refer to. |
Schema.Builder |
Schema.Builder.columnByExpression(String columnName,
Expression expression)
Declares a computed column that is appended to this schema.
|
TemporalTableFunction |
Table.createTemporalTableFunction(Expression timeAttribute,
Expression primaryKey)
Creates
TemporalTableFunction backed up by this table as a history table. |
Table |
Table.dropColumns(Expression... fields)
Drops existing columns.
|
SlideWithSizeAndSlide |
SlideWithSize.every(Expression slide)
Specifies the window's slide as time or row-count interval.
|
Table |
Table.filter(Expression predicate)
Filters out elements that don't pass the filter predicate.
|
FlatAggregateTable |
Table.flatAggregate(Expression tableAggregateFunction)
Perform a global flatAggregate without groupBy.
|
FlatAggregateTable |
WindowGroupedTable.flatAggregate(Expression tableAggregateFunction)
Performs a flatAggregate operation on a window grouped table.
|
FlatAggregateTable |
GroupedTable.flatAggregate(Expression tableAggFunction)
Performs a flatAggregate operation on a grouped table.
|
Table |
Table.flatMap(Expression tableFunction)
Performs a flatMap operation with an user-defined table function or built-in table function.
|
OverWindowPartitionedOrderedPreceding |
OverWindowPartitionedOrderedPreceding.following(Expression following)
Set the following offset (based on time or row-count intervals) for over window.
|
Table |
TableEnvironment.fromValues(AbstractDataType<?> rowType,
Expression... values)
Creates a Table from given collection of objects with a given row type.
|
Table |
TableEnvironment.fromValues(Expression... values)
Creates a Table from given values.
|
Table |
Table.fullOuterJoin(Table right,
Expression joinPredicate)
Joins two
Table s. |
GroupedTable |
Table.groupBy(Expression... fields)
Groups the elements on some grouping keys.
|
WindowGroupedTable |
GroupWindowedTable.groupBy(Expression... fields)
Groups the elements by a mandatory window and one or more optional grouping attributes.
|
Table |
Table.join(Table right,
Expression joinPredicate)
Joins two
Table s. |
Table |
Table.joinLateral(Expression tableFunctionCall)
Joins this
Table with an user-defined TableFunction . |
Table |
Table.joinLateral(Expression tableFunctionCall,
Expression joinPredicate)
Joins this
Table with an user-defined TableFunction . |
Table |
Table.leftOuterJoin(Table right,
Expression joinPredicate)
Joins two
Table s. |
Table |
Table.leftOuterJoinLateral(Expression tableFunctionCall)
Joins this
Table with an user-defined TableFunction . |
Table |
Table.leftOuterJoinLateral(Expression tableFunctionCall,
Expression joinPredicate)
Joins this
Table with an user-defined TableFunction . |
Table |
Table.map(Expression mapFunction)
Performs a map operation with an user-defined scalar function or built-in scalar function.
|
TumbleWithSizeOnTime |
TumbleWithSize.on(Expression timeField)
Specifies the time attribute on which rows are grouped.
|
SlideWithSizeAndSlideOnTime |
SlideWithSizeAndSlide.on(Expression timeField)
Specifies the time attribute on which rows are grouped.
|
SessionWithGapOnTime |
SessionWithGap.on(Expression timeField)
Specifies the time attribute on which rows are grouped.
|
Table |
Table.orderBy(Expression... fields)
Sorts the given
Table . |
static OverWindowPartitionedOrdered |
Over.orderBy(Expression orderBy)
Specifies the time attribute on which rows are ordered.
|
OverWindowPartitionedOrdered |
OverWindowPartitioned.orderBy(Expression orderBy)
Specifies the time attribute on which rows are ordered.
|
static SlideWithSize |
Slide.over(Expression size)
Creates a sliding window.
|
static TumbleWithSize |
Tumble.over(Expression size)
Creates a tumbling window.
|
static OverWindowPartitioned |
Over.partitionBy(Expression... partitionBy)
Partitions the elements on some partition keys.
|
OverWindowPartitionedOrderedPreceding |
OverWindowPartitionedOrdered.preceding(Expression preceding)
Set the preceding offset (based on time or row-count intervals) for over window.
|
Table |
Table.renameColumns(Expression... fields)
Renames existing columns.
|
Table |
Table.rightOuterJoin(Table right,
Expression joinPredicate)
Joins two
Table s. |
Table |
FlatAggregateTable.select(Expression... fields)
Performs a selection operation on a FlatAggregateTable table.
|
Table |
Table.select(Expression... fields)
Performs a selection operation.
|
Table |
OverWindowedTable.select(Expression... fields)
Performs a selection operation on a over windowed table.
|
Table |
WindowGroupedTable.select(Expression... fields)
Performs a selection operation on a window grouped table.
|
Table |
AggregatedTable.select(Expression... fields)
Performs a selection operation after an aggregate operation.
|
Table |
GroupedTable.select(Expression... fields)
Performs a selection operation on a grouped table.
|
protected ApiExpression |
ApiExpression.toApiSpecificExpression(Expression expression) |
Schema.Builder |
Schema.Builder.watermark(String columnName,
Expression watermarkExpression)
Declares that the given column should serve as an event-time (i.e.
|
Table |
Table.where(Expression predicate)
Filters out elements that don't pass the filter predicate.
|
static SessionWithGap |
Session.withGap(Expression gap)
Creates a session window.
|
Modifier and Type | Method and Description |
---|---|
protected <T> DataStreamQueryOperation<T> |
AbstractStreamTableEnvironmentImpl.asQueryOperation(DataStream<T> dataStream,
Optional<List<Expression>> fields) |
Modifier and Type | Method and Description |
---|---|
<T> void |
StreamTableEnvironment.createTemporaryView(String path,
DataStream<T> dataStream,
Expression... fields)
Deprecated.
Use
StreamTableEnvironment.createTemporaryView(String, DataStream, Schema) instead. In most
cases, StreamTableEnvironment.createTemporaryView(String, DataStream) should already be sufficient. It
integrates with the new type system and supports all kinds of DataTypes that the
table runtime can consume. The semantics might be slightly different for raw and
structured types. |
<T> Table |
StreamTableEnvironment.fromDataStream(DataStream<T> dataStream,
Expression... fields)
Deprecated.
Use
StreamTableEnvironment.fromDataStream(DataStream, Schema) instead. In most cases, StreamTableEnvironment.fromDataStream(DataStream) should already be sufficient. It integrates with the new
type system and supports all kinds of DataTypes that the table runtime can
consume. The semantics might be slightly different for raw and structured types. |
Modifier and Type | Method and Description |
---|---|
<T> void |
StreamTableEnvironmentImpl.createTemporaryView(String path,
DataStream<T> dataStream,
Expression... fields) |
<T> Table |
StreamTableEnvironmentImpl.fromDataStream(DataStream<T> dataStream,
Expression... fields) |
Modifier and Type | Method and Description |
---|---|
protected abstract Expression |
BaseExpressions.toExpr() |
Modifier and Type | Method and Description |
---|---|
Table |
TableImpl.addColumns(Expression... fields) |
Table |
TableImpl.addOrReplaceColumns(Expression... fields) |
AggregatedTable |
TableImpl.aggregate(Expression aggregateFunction) |
Table |
TableImpl.as(Expression... fields) |
TemporalTableFunction |
TableImpl.createTemporalTableFunction(Expression timeAttribute,
Expression primaryKey) |
Table |
TableImpl.dropColumns(Expression... fields) |
Table |
TableImpl.filter(Expression predicate) |
FlatAggregateTable |
TableImpl.flatAggregate(Expression tableAggregateFunction) |
Table |
TableImpl.flatMap(Expression tableFunction) |
Table |
TableEnvironmentImpl.fromValues(AbstractDataType<?> rowType,
Expression... values) |
Table |
TableEnvironmentImpl.fromValues(Expression... values) |
Table |
TableImpl.fullOuterJoin(Table right,
Expression joinPredicate) |
GroupedTable |
TableImpl.groupBy(Expression... fields) |
Table |
TableImpl.join(Table right,
Expression joinPredicate) |
Table |
TableImpl.joinLateral(Expression tableFunctionCall) |
Table |
TableImpl.joinLateral(Expression tableFunctionCall,
Expression joinPredicate) |
Table |
TableImpl.leftOuterJoin(Table right,
Expression joinPredicate) |
Table |
TableImpl.leftOuterJoinLateral(Expression tableFunctionCall) |
Table |
TableImpl.leftOuterJoinLateral(Expression tableFunctionCall,
Expression joinPredicate) |
Table |
TableImpl.map(Expression mapFunction) |
Table |
TableImpl.orderBy(Expression... fields) |
Table |
TableImpl.renameColumns(Expression... fields) |
Table |
TableImpl.rightOuterJoin(Table right,
Expression joinPredicate) |
Table |
TableImpl.select(Expression... fields) |
protected abstract OutType |
BaseExpressions.toApiSpecificExpression(Expression expression) |
Table |
TableImpl.where(Expression predicate) |
Modifier and Type | Method and Description |
---|---|
List<CatalogPartitionSpec> |
GenericInMemoryCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters) |
List<CatalogPartitionSpec> |
Catalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters)
Get CatalogPartitionSpec of partitions by expression filters in the table.
|
Modifier and Type | Method and Description |
---|---|
List<CatalogPartitionSpec> |
HiveCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> expressions) |
Modifier and Type | Method and Description |
---|---|
static Optional<String> |
HiveTableUtil.makePartitionFilter(int partColOffset,
List<String> partColNames,
List<Expression> expressions,
HiveShim hiveShim)
Generates a filter string for partition columns from the given filter expressions.
|
Modifier and Type | Method and Description |
---|---|
Expression |
ExpressionParser.parseExpression(String exprString)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
List<Expression> |
ExpressionParser.parseExpressionList(String expression)
Deprecated.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ResolvedExpression
Expression that has been fully resolved and validated.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateExpression
Resolved and validated expression for calling an aggregate function.
|
class |
CallExpression
Resolved and validated call expression for calling a function.
|
class |
FieldReferenceExpression
A reference to a field in an input.
|
class |
LocalReferenceExpression
Reference to entity local to a certain
QueryOperation . |
class |
LookupCallExpression
A call expression where the target function has not been resolved yet.
|
class |
SqlCallExpression
A call to a SQL expression.
|
class |
TableReferenceExpression
Expression that references another table.
|
class |
TypeLiteralExpression
Expression that wraps
DataType as a literal. |
class |
UnresolvedCallExpression
Unresolved call expression for calling a function identified by a
FunctionDefinition . |
class |
UnresolvedReferenceExpression
An unresolved reference to a field, table, or local reference.
|
class |
ValueLiteralExpression
Expression for constant literal values.
|
Modifier and Type | Method and Description |
---|---|
static Expression |
ApiExpressionUtils.objectToExpression(Object expression)
Converts a given object to an expression.
|
static Expression |
ApiExpressionUtils.toMilliInterval(Expression e,
long multiplier) |
static Expression |
ApiExpressionUtils.toMonthInterval(Expression e,
int multiplier) |
static Expression |
ApiExpressionUtils.toRowInterval(Expression e) |
static Expression |
ApiExpressionUtils.unwrapFromApi(Expression expression) |
Modifier and Type | Method and Description |
---|---|
List<Expression> |
LocalReferenceExpression.getChildren() |
List<Expression> |
UnresolvedCallExpression.getChildren() |
List<Expression> |
LookupCallExpression.getChildren() |
List<Expression> |
UnresolvedReferenceExpression.getChildren() |
List<Expression> |
TableReferenceExpression.getChildren() |
List<Expression> |
SqlCallExpression.getChildren() |
List<Expression> |
TypeLiteralExpression.getChildren() |
List<Expression> |
FieldReferenceExpression.getChildren() |
List<Expression> |
CallExpression.getChildren() |
List<Expression> |
AggregateExpression.getChildren() |
List<Expression> |
ValueLiteralExpression.getChildren() |
List<Expression> |
Expression.getChildren() |
Modifier and Type | Method and Description |
---|---|
protected abstract T |
ExpressionDefaultVisitor.defaultMethod(Expression expression) |
static <V> Optional<V> |
ExpressionUtils.extractValue(Expression expression,
Class<V> targetClass)
Extracts the value (excluding null) of a given class from an expression assuming it is a
ValueLiteralExpression . |
static boolean |
ApiExpressionUtils.isFunction(Expression expression,
BuiltInFunctionDefinition functionDefinition)
Checks if the given expression is a given builtin function.
|
static boolean |
ApiExpressionUtils.isFunctionOfKind(Expression expression,
FunctionKind kind)
Checks if the expression is a function call of given type.
|
static LookupCallExpression |
ApiExpressionUtils.lookupCall(String name,
Expression... args) |
static Expression |
ApiExpressionUtils.toMilliInterval(Expression e,
long multiplier) |
static Expression |
ApiExpressionUtils.toMonthInterval(Expression e,
int multiplier) |
static Expression |
ApiExpressionUtils.toRowInterval(Expression e) |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(ContextResolvedFunction resolvedFunction,
Expression... args) |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(FunctionDefinition functionDefinition,
Expression... args) |
static Expression |
ApiExpressionUtils.unwrapFromApi(Expression expression) |
R |
ResolvedExpressionVisitor.visit(Expression other) |
R |
ApiExpressionVisitor.visit(Expression other) |
T |
ExpressionDefaultVisitor.visit(Expression other) |
R |
ExpressionVisitor.visit(Expression other) |
abstract R |
ApiExpressionVisitor.visitNonApiExpression(Expression other) |
Modifier and Type | Method and Description |
---|---|
UnresolvedCallExpression |
UnresolvedCallExpression.replaceArgs(List<Expression> args) |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(ContextResolvedFunction resolvedFunction,
List<Expression> args) |
static UnresolvedCallExpression |
ApiExpressionUtils.unresolvedCall(FunctionDefinition functionDefinition,
List<Expression> args) |
Modifier and Type | Method and Description |
---|---|
protected Expression |
LookupCallResolver.defaultMethod(Expression expression) |
Expression |
LocalOverWindow.getAlias() |
Expression |
LocalOverWindow.getOrderBy() |
Expression |
LocalOverWindow.getPreceding() |
Expression |
LookupCallResolver.visit(LookupCallExpression lookupCall) |
Expression |
LookupCallResolver.visit(UnresolvedCallExpression unresolvedCall) |
Expression |
LookupCallResolver.visitNonApiExpression(Expression other) |
Modifier and Type | Method and Description |
---|---|
Optional<Expression> |
LocalOverWindow.getFollowing() |
List<Expression> |
LocalOverWindow.getPartitionBy() |
List<Expression> |
ExpressionResolver.resolveExpanding(List<Expression> expressions)
Resolves given expressions with configured set of rules.
|
Modifier and Type | Method and Description |
---|---|
protected Expression |
LookupCallResolver.defaultMethod(Expression expression) |
Expression |
LookupCallResolver.visitNonApiExpression(Expression other) |
Modifier and Type | Method and Description |
---|---|
List<ResolvedExpression> |
ExpressionResolver.resolve(List<Expression> expressions)
Resolves given expressions with configured set of rules.
|
List<Expression> |
ExpressionResolver.resolveExpanding(List<Expression> expressions)
Resolves given expressions with configured set of rules.
|
Modifier and Type | Method and Description |
---|---|
List<Expression> |
ResolverRule.apply(List<Expression> expression,
ResolverRule.ResolutionContext context) |
Modifier and Type | Method and Description |
---|---|
Optional<LocalOverWindow> |
ResolverRule.ResolutionContext.getOverWindow(Expression alias)
Access to available local over windows.
|
Modifier and Type | Method and Description |
---|---|
List<Expression> |
ResolverRule.apply(List<Expression> expression,
ResolverRule.ResolutionContext context) |
Modifier and Type | Method and Description |
---|---|
protected abstract T |
ApiExpressionDefaultVisitor.defaultMethod(Expression expression) |
T |
ApiExpressionDefaultVisitor.visitNonApiExpression(Expression other) |
Modifier and Type | Method and Description |
---|---|
Expression |
TemporalTableFunctionImpl.getPrimaryKey() |
Expression |
TemporalTableFunctionImpl.getTimeAttribute() |
Modifier and Type | Method and Description |
---|---|
static TemporalTableFunction |
TemporalTableFunctionImpl.create(QueryOperation operationTree,
Expression timeAttribute,
Expression primaryKey) |
Modifier and Type | Method and Description |
---|---|
Expression |
OperationTreeBuilder.resolveExpression(Expression expression,
QueryOperation... tableOperation) |
Modifier and Type | Method and Description |
---|---|
List<Expression> |
OperationExpressionsUtils.CategorizedExpressions.getAggregations() |
List<Expression> |
OperationExpressionsUtils.CategorizedExpressions.getProjections() |
List<Expression> |
OperationExpressionsUtils.CategorizedExpressions.getWindowProperties() |
Modifier and Type | Method and Description |
---|---|
QueryOperation |
OperationTreeBuilder.aggregate(List<Expression> groupingExpressions,
Expression aggregate,
QueryOperation child) |
static Optional<String> |
OperationExpressionsUtils.extractName(Expression expression)
Extracts name from given expression if it has one.
|
QueryOperation |
OperationTreeBuilder.filter(Expression condition,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.flatMap(Expression tableFunctionCall,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.joinLateral(QueryOperation left,
Expression tableFunction,
JoinQueryOperation.JoinType joinType,
Optional<Expression> condition) |
QueryOperation |
OperationTreeBuilder.map(Expression mapFunction,
QueryOperation child) |
Expression |
OperationTreeBuilder.resolveExpression(Expression expression,
QueryOperation... tableOperation) |
QueryOperation |
OperationTreeBuilder.tableAggregate(List<Expression> groupingExpressions,
Expression tableAggFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.values(DataType rowType,
Expression... expressions) |
QueryOperation |
OperationTreeBuilder.values(Expression... expressions) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression aggregateFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowTableAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression tableAggFunction,
QueryOperation child) |
Modifier and Type | Method and Description |
---|---|
QueryOperation |
OperationTreeBuilder.addColumns(boolean replaceIfExist,
List<Expression> fieldLists,
QueryOperation child)
Adds additional columns.
|
QueryOperation |
OperationTreeBuilder.aggregate(List<Expression> groupingExpressions,
Expression aggregate,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.aggregate(List<Expression> groupingExpressions,
List<Expression> aggregates,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.aggregate(List<Expression> groupingExpressions,
List<Expression> aggregates,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.alias(List<Expression> fields,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.dropColumns(List<Expression> fieldLists,
QueryOperation child) |
static OperationExpressionsUtils.CategorizedExpressions |
OperationExpressionsUtils.extractAggregationsAndProperties(List<Expression> expressions)
Extracts and deduplicates all aggregation and window property expressions (zero, one, or
more) from the given expressions.
|
QueryOperation |
OperationTreeBuilder.join(QueryOperation left,
QueryOperation right,
JoinQueryOperation.JoinType joinType,
Optional<Expression> condition,
boolean correlated) |
QueryOperation |
OperationTreeBuilder.joinLateral(QueryOperation left,
Expression tableFunction,
JoinQueryOperation.JoinType joinType,
Optional<Expression> condition) |
QueryOperation |
OperationTreeBuilder.project(List<Expression> projectList,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.project(List<Expression> projectList,
QueryOperation child,
boolean explicitAlias) |
QueryOperation |
OperationTreeBuilder.project(List<Expression> projectList,
QueryOperation child,
List<OverWindow> overWindows) |
QueryOperation |
OperationTreeBuilder.renameColumns(List<Expression> aliases,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.sort(List<Expression> fields,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.tableAggregate(List<Expression> groupingExpressions,
Expression tableAggFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression aggregateFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression aggregateFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
List<Expression> aggregates,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
List<Expression> aggregates,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
List<Expression> aggregates,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowTableAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression tableAggFunction,
QueryOperation child) |
QueryOperation |
OperationTreeBuilder.windowTableAggregate(List<Expression> groupingExpressions,
GroupWindow window,
List<Expression> windowProperties,
Expression tableAggFunction,
QueryOperation child) |
Modifier and Type | Class and Description |
---|---|
class |
RexNodeExpression
Wrapper for a
ResolvedExpression that originated from a RexNode . |
Modifier and Type | Method and Description |
---|---|
List<Expression> |
RexNodeExpression.getChildren() |
Modifier and Type | Method and Description |
---|---|
static UnresolvedCallExpression |
ExpressionBuilder.aggDecimalMinus(Expression input1,
Expression input2)
Used only for implementing SUM/AVG aggregations (with and without retractions) on a Decimal
type to avoid overriding decimal precision/scale calculation for sum/avg with the rules
applied for the normal minus.
|
static UnresolvedCallExpression |
ExpressionBuilder.aggDecimalPlus(Expression input1,
Expression input2)
Used only for implementing SUM/AVG aggregations (with and without retractions) on a Decimal
type to avoid overriding decimal precision/scale calculation for sum/avg with the rules
applied for the normal plus.
|
static UnresolvedCallExpression |
ExpressionBuilder.and(Expression arg1,
Expression arg2) |
static UnresolvedCallExpression |
ExpressionBuilder.call(FunctionDefinition functionDefinition,
Expression... args) |
static UnresolvedCallExpression |
ExpressionBuilder.cast(Expression child,
Expression type) |
static UnresolvedCallExpression |
ExpressionBuilder.concat(Expression input1,
Expression input2) |
protected org.apache.calcite.sql.SqlAggFunction |
SqlAggFunctionVisitor.defaultMethod(Expression expression) |
protected ResolvedExpression |
DeclarativeExpressionResolver.defaultMethod(Expression expression) |
static UnresolvedCallExpression |
ExpressionBuilder.div(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.equalTo(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.greaterThan(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.ifThenElse(Expression condition,
Expression ifTrue,
Expression ifFalse) |
static UnresolvedCallExpression |
ExpressionBuilder.isNull(Expression input) |
static UnresolvedCallExpression |
ExpressionBuilder.lessThan(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.minus(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.mod(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.not(Expression arg) |
static UnresolvedCallExpression |
ExpressionBuilder.or(Expression arg1,
Expression arg2) |
static UnresolvedCallExpression |
ExpressionBuilder.plus(Expression input1,
Expression input2) |
static UnresolvedCallExpression |
ExpressionBuilder.reinterpretCast(Expression child,
Expression type,
boolean checkOverflow) |
ResolvedExpression |
CallExpressionResolver.resolve(Expression expression) |
static UnresolvedCallExpression |
ExpressionBuilder.times(Expression input1,
Expression input2) |
Modifier and Type | Method and Description |
---|---|
static UnresolvedCallExpression |
ExpressionBuilder.call(FunctionDefinition functionDefinition,
List<Expression> args) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.rex.RexNode |
CallExpressionConvertRule.ConvertContext.toRexNode(Expression expr)
Convert expression to RexNode, used by children conversion.
|
org.apache.calcite.rex.RexNode |
ExpressionConverter.visit(Expression other) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.calcite.rex.RexNode> |
ExpressionConverter.toRexNodes(CallExpressionConvertRule.ConvertContext context,
List<Expression> expr) |
Modifier and Type | Method and Description |
---|---|
Expression[] |
RankAggFunction.accumulateExpressions() |
Expression[] |
RowNumberAggFunction.accumulateExpressions() |
Expression[] |
CountAggFunction.accumulateExpressions() |
Expression[] |
SingleValueAggFunction.accumulateExpressions() |
Expression[] |
LeadLagAggFunction.accumulateExpressions() |
Expression[] |
MaxAggFunction.accumulateExpressions() |
abstract Expression[] |
DeclarativeAggregateFunction.accumulateExpressions()
Expressions for accumulating the mutable aggregation buffer based on an input row.
|
Expression[] |
MinAggFunction.accumulateExpressions() |
Expression[] |
AvgAggFunction.accumulateExpressions() |
Expression[] |
Sum0AggFunction.accumulateExpressions() |
Expression[] |
ListAggFunction.accumulateExpressions() |
Expression[] |
SumAggFunction.accumulateExpressions() |
Expression[] |
DenseRankAggFunction.accumulateExpressions() |
Expression[] |
SumWithRetractAggFunction.accumulateExpressions() |
Expression[] |
Count1AggFunction.accumulateExpressions() |
protected Expression |
RankLikeAggFunctionBase.generateInitLiteral(LogicalType orderType) |
Expression |
RowNumberAggFunction.getValueExpression() |
Expression |
CountAggFunction.getValueExpression() |
Expression |
SingleValueAggFunction.getValueExpression() |
Expression |
LeadLagAggFunction.getValueExpression() |
Expression |
MaxAggFunction.getValueExpression() |
abstract Expression |
DeclarativeAggregateFunction.getValueExpression()
An expression which returns the final value for this aggregate function.
|
Expression |
MinAggFunction.getValueExpression() |
Expression |
AvgAggFunction.getValueExpression()
If all input are nulls, count will be 0 and we will get null after the division.
|
Expression |
Sum0AggFunction.getValueExpression() |
Expression |
ListAggFunction.getValueExpression() |
Expression |
SumAggFunction.getValueExpression() |
Expression |
RankLikeAggFunctionBase.getValueExpression() |
Expression |
SumWithRetractAggFunction.getValueExpression() |
Expression |
Count1AggFunction.getValueExpression() |
Expression[] |
RankAggFunction.initialValuesExpressions() |
Expression[] |
RowNumberAggFunction.initialValuesExpressions() |
Expression[] |
CountAggFunction.initialValuesExpressions() |
Expression[] |
SingleValueAggFunction.initialValuesExpressions() |
Expression[] |
LeadLagAggFunction.initialValuesExpressions() |
Expression[] |
MaxAggFunction.initialValuesExpressions() |
abstract Expression[] |
DeclarativeAggregateFunction.initialValuesExpressions()
Expressions for initializing empty aggregation buffers.
|
Expression[] |
MinAggFunction.initialValuesExpressions() |
Expression[] |
AvgAggFunction.initialValuesExpressions() |
Expression[] |
AvgAggFunction.FloatAvgAggFunction.initialValuesExpressions() |
Expression[] |
AvgAggFunction.DoubleAvgAggFunction.initialValuesExpressions() |
Expression[] |
AvgAggFunction.DecimalAvgAggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.IntSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.ByteSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.ShortSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.LongSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.FloatSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.DoubleSum0AggFunction.initialValuesExpressions() |
Expression[] |
Sum0AggFunction.DecimalSum0AggFunction.initialValuesExpressions() |
Expression[] |
ListAggFunction.initialValuesExpressions() |
Expression[] |
SumAggFunction.initialValuesExpressions() |
Expression[] |
DenseRankAggFunction.initialValuesExpressions() |
Expression[] |
SumWithRetractAggFunction.initialValuesExpressions() |
Expression[] |
Count1AggFunction.initialValuesExpressions() |
Expression[] |
RowNumberAggFunction.mergeExpressions() |
Expression[] |
CountAggFunction.mergeExpressions() |
Expression[] |
SingleValueAggFunction.mergeExpressions() |
Expression[] |
LeadLagAggFunction.mergeExpressions() |
Expression[] |
MaxAggFunction.mergeExpressions() |
abstract Expression[] |
DeclarativeAggregateFunction.mergeExpressions()
A sequence of expressions for merging two aggregation buffers together.
|
Expression[] |
MinAggFunction.mergeExpressions() |
Expression[] |
AvgAggFunction.mergeExpressions() |
Expression[] |
Sum0AggFunction.mergeExpressions() |
Expression[] |
ListAggFunction.mergeExpressions() |
Expression[] |
SumAggFunction.mergeExpressions() |
Expression[] |
RankLikeAggFunctionBase.mergeExpressions() |
Expression[] |
SumWithRetractAggFunction.mergeExpressions() |
Expression[] |
Count1AggFunction.mergeExpressions() |
protected Expression |
RankLikeAggFunctionBase.orderKeyEqualsExpression() |
Expression[] |
RowNumberAggFunction.retractExpressions() |
Expression[] |
CountAggFunction.retractExpressions() |
Expression[] |
SingleValueAggFunction.retractExpressions() |
Expression[] |
LeadLagAggFunction.retractExpressions() |
Expression[] |
MaxAggFunction.retractExpressions() |
abstract Expression[] |
DeclarativeAggregateFunction.retractExpressions()
Expressions for retracting the mutable aggregation buffer based on an input row.
|
Expression[] |
MinAggFunction.retractExpressions() |
Expression[] |
AvgAggFunction.retractExpressions() |
Expression[] |
Sum0AggFunction.retractExpressions() |
Expression[] |
ListAggFunction.retractExpressions() |
Expression[] |
SumAggFunction.retractExpressions() |
Expression[] |
RankLikeAggFunctionBase.retractExpressions() |
Expression[] |
SumWithRetractAggFunction.retractExpressions() |
Expression[] |
Count1AggFunction.retractExpressions() |
protected abstract Expression |
SumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.IntSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.ByteSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.ShortSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.LongSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.FloatSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.DoubleSumWithRetractAggFunction.zeroLiteral() |
protected Expression |
SumWithRetractAggFunction.DecimalSumWithRetractAggFunction.zeroLiteral() |
Modifier and Type | Method and Description |
---|---|
protected UnresolvedCallExpression |
SumWithRetractAggFunction.adjustedMinus(Expression arg1,
UnresolvedReferenceExpression arg2) |
protected UnresolvedCallExpression |
SumWithRetractAggFunction.DecimalSumWithRetractAggFunction.adjustedMinus(Expression arg1,
UnresolvedReferenceExpression arg2) |
Modifier and Type | Method and Description |
---|---|
Expression |
FieldComputer.getExpression(ResolvedFieldReference[] fieldAccesses)
Deprecated.
Returns the
Expression that computes the value of the field. |
Modifier and Type | Method and Description |
---|---|
TableSource<T> |
FilterableTableSource.applyPredicate(List<Expression> predicates)
Deprecated.
Check and pick all predicates this table source can support.
|
Modifier and Type | Method and Description |
---|---|
Expression |
ExistingField.getExpression(ResolvedFieldReference[] fieldAccesses)
Returns an
Expression that casts a Long , Timestamp , or timestamp
formatted String field (e.g., "2018-05-28 12:34:56.000") into a rowtime attribute. |
Expression |
StreamRecordTimestamp.getExpression(ResolvedFieldReference[] fieldAccesses) |
Modifier and Type | Method and Description |
---|---|
static <A> FieldInfoUtils.TypeInfoSchema |
FieldInfoUtils.getFieldsInfo(TypeInformation<A> inputType,
Expression[] expressions)
Returns a
FieldInfoUtils.TypeInfoSchema for a given TypeInformation . |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.