Class | Description |
---|---|
CalcPythonCorrelateTransposeRule |
Rule will transpose the conditions after the Python correlate node if the join type is inner
join.
|
FlinkAggregateExpandDistinctAggregatesRule |
Planner rule that expands distinct aggregates (such as
COUNT(DISTINCT x) ) from a Aggregate . |
FlinkAggregateJoinTransposeRule |
Planner rule that pushes an
Aggregate past a Join . |
FlinkAggregateRemoveRule |
Planner rule that removes a
Aggregate if its aggregate
functions are SUM, MIN, MAX, AUXILIARY_GROUP with no filterArgs, and the underlying relational
expression is already distinct. |
FlinkJoinPushExpressionsRule |
Planner rule that pushes down expressions in "equal" join condition.
|
FlinkLogicalCalcRemoveRule |
Rule to remove trivial
FlinkLogicalCalc . |
FlinkProjectJoinTransposeRule |
Planner rule that pushes a
Project past a Join by splitting the projection into a projection on top of each
child of the join. |
FlinkSemiAntiJoinFilterTransposeRule |
Planner rule that pushes semi-join down in a tree past a
Filter . |
FlinkSemiAntiJoinJoinTransposeRule |
Planner rule that pushes a
org.apache.calcite.rel.core.SemiJoin down in a tree past a
Join in order to trigger other rules that will convert SemiJoin s. |
FlinkSemiAntiJoinProjectTransposeRule |
Planner rule that pushes a
org.apache.calcite.rel.core.SemiJoin down in a tree past a
Project . |
ProjectWatermarkAssignerTransposeRule |
Transpose between the
LogicalWatermarkAssigner and LogicalProject . |
PushFilterIntoTableSourceScanRule |
Planner rule that tries to push a filter into a
LogicalTableScan , which table is a TableSourceTable . |
PushLimitIntoTableSourceScanRule |
Planner rule that tries to push limit into a
FlinkLogicalTableSourceScan , which table is
a TableSourceTable . |
PushPartitionIntoTableSourceScanRule |
Planner rule that tries to push partition evaluated by filter condition into a
LogicalTableScan . |
PushProjectIntoTableSourceScanRule |
Planner rule that pushes a
LogicalProject into a LogicalTableScan which wraps a
SupportsProjectionPushDown dynamic table source. |
PushWatermarkIntoTableSourceScanAcrossCalcRule |
Rule to push the
FlinkLogicalWatermarkAssigner across the FlinkLogicalCalc to the
FlinkLogicalTableSourceScan . |
PushWatermarkIntoTableSourceScanRule |
Rule to push the
FlinkLogicalWatermarkAssigner into the FlinkLogicalTableSourceScan . |
PushWatermarkIntoTableSourceScanRuleBase |
Base rule for interface
SupportsWatermarkPushDown . |
PythonCorrelateSplitRule |
Rule will split the Python
FlinkLogicalTableFunctionScan with Java calls or the Java
FlinkLogicalTableFunctionScan with Python calls into a FlinkLogicalCalc which
will be the left input of the new FlinkLogicalCorrelate and a new FlinkLogicalTableFunctionScan . |
SubQueryDecorrelator |
SubQueryDecorrelator finds all correlated expressions in a SubQuery, and gets an equivalent
non-correlated relational expression tree and correlation conditions.
|
SubQueryDecorrelator.Result |
Result describing the relational expression after decorrelation and where to find the
equivalent non-correlated expressions and correlated conditions.
|
SubQueryDecorrelator.SubQueryRelDecorrelator |
Pull out all correlation conditions from a given subquery to top level, and rebuild the
subquery rel tree without correlation conditions.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.