Interface | Description |
---|---|
EventTimeTemporalJoinRewriteRule.Config |
Configuration for
EventTimeTemporalJoinRewriteRule . |
FlinkFilterJoinRule.Config |
Rule configuration.
|
FlinkFilterJoinRule.FlinkFilterIntoJoinRule.Config |
Rule configuration.
|
FlinkFilterJoinRule.FlinkJoinConditionPushRule.Config |
Rule configuration.
|
FlinkFilterJoinRule.Predicate |
Predicate that returns whether a filter is valid in the ON clause of a join for this
particular kind of join.
|
FlinkJoinToMultiJoinRule.Config |
Rule configuration.
|
ProjectSnapshotTransposeRule.Config |
Configuration for
ProjectSnapshotTransposeRule . |
PushProjectIntoTableSourceScanRule.Config |
Configuration for
PushProjectIntoTableSourceScanRule . |
RemoveUnreachableCoalesceArgumentsRule.Config |
Configuration for
RemoveUnreachableCoalesceArgumentsRule . |
WrapJsonAggFunctionArgumentsRule.Config |
Configuration for
WrapJsonAggFunctionArgumentsRule . |
Class | Description |
---|---|
CalcPythonCorrelateTransposeRule |
Rule will transpose the conditions after the Python correlate node if the join type is inner
join.
|
EventTimeTemporalJoinRewriteRule |
Traverses an event time temporal table join
RelNode tree and update the right child to
set FlinkLogicalTableSourceScan 's eventTimeSnapshot property to true which will prevent
it generating a new StreamPhysicalChangelogNormalize later. |
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. |
FlinkFilterJoinRule<C extends FlinkFilterJoinRule.Config> |
Planner rule that pushes filters above and within a join node into the join node and/or its
children nodes.
|
FlinkFilterJoinRule.FlinkFilterIntoJoinRule |
Rule that tries to push filter expressions into a join condition and into the inputs of the
join.
|
FlinkFilterJoinRule.FlinkJoinConditionPushRule |
Rule that pushes parts of the join condition to its inputs.
|
FlinkJoinPushExpressionsRule |
Planner rule that pushes down expressions in "equal" join condition.
|
FlinkJoinToMultiJoinRule |
Flink Planner rule to flatten a tree of
LogicalJoin s into a single MultiJoin with
N inputs. |
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 . |
JoinTableFunctionScanToCorrelateRule |
Rule that rewrites Join on TableFunctionScan to Correlate.
|
ProjectSnapshotTransposeRule |
Transpose
LogicalProject past into LogicalSnapshot . |
ProjectWatermarkAssignerTransposeRule |
Transpose between the
LogicalWatermarkAssigner and LogicalProject . |
ProjectWindowTableFunctionTransposeRule |
Planner rule that pushes a
LogicalProject into a LogicalTableFunctionScan which
contains a Window table function call by splitting the projection into a projection on top of
child of the TableFunctionScan. |
PushFilterInCalcIntoTableSourceScanRule |
Pushes a filter condition from the
FlinkLogicalCalc and into a FlinkLogicalTableSourceScan . |
PushFilterIntoSourceScanRuleBase |
Base class for rules that push down filters into table scan.
|
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 |
Pushes a
LogicalProject into a LogicalTableScan . |
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 and SupportsSourceWatermark . |
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 . |
PythonMapMergeRule |
Rule will merge Python
FlinkLogicalCalc used in Map operation, Flatten FlinkLogicalCalc and Python FlinkLogicalCalc used in Map operation together. |
PythonMapRenameRule |
Rule which renames the field names of the Flatten
FlinkLogicalCalc which is right after a
FlinkLogicalCalc representing a Python Map operation to the output names of the map
function. |
RedundantRankNumberColumnRemoveRule |
Planner rule that removes the output column of rank number iff the rank number column is not used
by successor calc.
|
RemoveUnreachableCoalesceArgumentsRule |
Removes unreachable
BuiltInFunctionDefinitions.COALESCE arguments. |
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.
|
WrapJsonAggFunctionArgumentsRule |
Transforms JSON aggregation functions by wrapping operands into
BuiltInFunctionDefinitions.JSON_STRING . |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.