Modifier and Type | Field and Description |
---|---|
static InputProperty |
InputProperty.DEFAULT |
Modifier and Type | Method and Description |
---|---|
InputProperty |
InputProperty.Builder.build() |
Modifier and Type | Method and Description |
---|---|
List<InputProperty> |
ExecNodeBase.getInputProperties() |
List<InputProperty> |
ExecNode.getInputProperties()
Returns a list of this node's input properties.
|
Constructor and Description |
---|
ExecNodeBase(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
Constructor and Description |
---|
BatchExecCalc(ReadableConfig tableConfig,
List<org.apache.calcite.rex.RexNode> projection,
org.apache.calcite.rex.RexNode condition,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecCorrelate(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
org.apache.calcite.rex.RexNode condition,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecExchange(ReadableConfig tableConfig,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecExpand(ReadableConfig tableConfig,
List<List<org.apache.calcite.rex.RexNode>> projects,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecHashAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
RowType aggInputRowType,
boolean isMerge,
boolean isFinal,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecHashJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
int estimatedLeftAvgRowSize,
int estimatedRightAvgRowSize,
long estimatedLeftRowCount,
long estimatedRightRowCount,
boolean leftIsBuild,
boolean tryDistinctBuildRow,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
BatchExecHashWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
int inputTimeFieldIndex,
boolean inputTimeIsDate,
NamedWindowProperty[] namedWindowProperties,
RowType aggInputRowType,
boolean enableAssignPane,
boolean isMerge,
boolean isFinal,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecLegacySink(ReadableConfig tableConfig,
TableSink<T> tableSink,
String[] upsertKeys,
InputProperty inputProperty,
LogicalType outputType,
String description) |
BatchExecLimit(ReadableConfig tableConfig,
long limitStart,
long limitEnd,
boolean isGlobal,
InputProperty inputProperty,
LogicalType outputType,
String description) |
BatchExecLookupJoin(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode joinCondition,
TemporalTableSourceSpec temporalTableSourceSpec,
Map<Integer,LookupJoinUtil.LookupKey> lookupKeys,
List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable,
org.apache.calcite.rex.RexNode filterOnTemporalTable,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecNestedLoopJoin(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode condition,
boolean leftIsBuild,
boolean singleRowJoin,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
BatchExecOverAggregate(ReadableConfig tableConfig,
OverSpec overSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecOverAggregateBase(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
OverSpec overSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecPythonCalc(ReadableConfig tableConfig,
List<org.apache.calcite.rex.RexNode> projection,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecPythonCorrelate(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecPythonGroupAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecPythonGroupWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
int inputTimeFieldIndex,
NamedWindowProperty[] namedWindowProperties,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecPythonOverAggregate(ReadableConfig tableConfig,
OverSpec overSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecRank(ReadableConfig tableConfig,
int[] partitionFields,
int[] sortFields,
long rankStart,
long rankEnd,
boolean outputRankNumber,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecSink(ReadableConfig tableConfig,
DynamicTableSinkSpec tableSinkSpec,
InputProperty inputProperty,
LogicalType outputType,
String description) |
BatchExecSort(ReadableConfig tableConfig,
SortSpec sortSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecSortAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
RowType aggInputRowType,
boolean isMerge,
boolean isFinal,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecSortLimit(ReadableConfig tableConfig,
SortSpec sortSpec,
long limitStart,
long limitEnd,
boolean isGlobal,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecSortMergeJoin(ReadableConfig tableConfig,
FlinkJoinType joinType,
int[] leftKeys,
int[] rightKeys,
boolean[] filterNulls,
org.apache.calcite.rex.RexNode nonEquiCondition,
boolean leftIsSmaller,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
BatchExecSortWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
int[] auxGrouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
int inputTimeFieldIndex,
boolean inputTimeIsDate,
NamedWindowProperty[] namedWindowProperties,
RowType aggInputRowType,
boolean enableAssignPane,
boolean isMerge,
boolean isFinal,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecWindowTableFunction(ReadableConfig tableConfig,
TimeAttributeWindowingStrategy windowingStrategy,
InputProperty inputProperty,
RowType outputType,
String description) |
Constructor and Description |
---|
BatchExecMultipleInput(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
ExecNode<?> rootNode,
List<ExecEdge> originalEdges,
String description) |
BatchExecUnion(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
Constructor and Description |
---|
CommonExecLegacySink(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
TableSink<T> tableSink,
String[] upsertKeys,
boolean needRetraction,
boolean isStreaming,
InputProperty inputProperty,
LogicalType outputType,
String description) |
Constructor and Description |
---|
CommonExecCalc(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<org.apache.calcite.rex.RexNode> projection,
org.apache.calcite.rex.RexNode condition,
Class<?> operatorBaseClass,
boolean retainHeader,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecCorrelate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
org.apache.calcite.rex.RexNode condition,
Class<?> operatorBaseClass,
boolean retainHeader,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecExchange(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecExpand(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<List<org.apache.calcite.rex.RexNode>> projects,
boolean retainHeader,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecLookupJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode joinCondition,
TemporalTableSourceSpec temporalTableSourceSpec,
Map<Integer,LookupJoinUtil.LookupKey> lookupKeys,
List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable,
org.apache.calcite.rex.RexNode filterOnTemporalTable,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecPythonCalc(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<org.apache.calcite.rex.RexNode> projection,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecPythonCorrelate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecSink(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
boolean isBounded,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
CommonExecUnion(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
CommonExecWindowTableFunction(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
TimeAttributeWindowingStrategy windowingStrategy,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
Constructor and Description |
---|
StreamExecCalc(ReadableConfig tableConfig,
List<org.apache.calcite.rex.RexNode> projection,
org.apache.calcite.rex.RexNode condition,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecChangelogNormalize(ReadableConfig tableConfig,
int[] uniqueKeys,
boolean generateUpdateBefore,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecCorrelate(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
org.apache.calcite.rex.RexNode condition,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecDeduplicate(ReadableConfig tableConfig,
int[] uniqueKeys,
boolean isRowtime,
boolean keepLastRow,
boolean generateUpdateBefore,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecDropUpdateBefore(ReadableConfig tableConfig,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecExchange(ReadableConfig tableConfig,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecExpand(ReadableConfig tableConfig,
List<List<org.apache.calcite.rex.RexNode>> projects,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecGlobalGroupAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
RowType localAggInputRowType,
boolean generateUpdateBefore,
boolean needRetraction,
Integer indexOfCountStar,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecGlobalWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
NamedWindowProperty[] namedWindowProperties,
InputProperty inputProperty,
RowType localAggInputRowType,
RowType outputType,
String description) |
StreamExecGroupAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecGroupTableAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecGroupWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecIncrementalGroupAggregate(ReadableConfig tableConfig,
int[] partialAggGrouping,
int[] finalAggGrouping,
org.apache.calcite.rel.core.AggregateCall[] partialOriginalAggCalls,
boolean[] partialAggCallNeedRetractions,
RowType partialLocalAggInputType,
boolean partialAggNeedRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecIntervalJoin(ReadableConfig tableConfig,
IntervalJoinSpec intervalJoinSpec,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
StreamExecJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
List<int[]> leftUniqueKeys,
List<int[]> rightUniqueKeys,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
StreamExecLegacySink(ReadableConfig tableConfig,
TableSink<T> tableSink,
String[] upsertKeys,
boolean needRetraction,
InputProperty inputProperty,
LogicalType outputType,
String description) |
StreamExecLimit(ReadableConfig tableConfig,
long limitStart,
long limitEnd,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecLocalGroupAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecLocalWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecLookupJoin(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode joinCondition,
TemporalTableSourceSpec temporalTableSourceSpec,
Map<Integer,LookupJoinUtil.LookupKey> lookupKeys,
List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable,
org.apache.calcite.rex.RexNode filterOnTemporalTable,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecMatch(ReadableConfig tableConfig,
MatchSpec matchSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecMiniBatchAssigner(ReadableConfig tableConfig,
MiniBatchInterval miniBatchInterval,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecOverAggregate(ReadableConfig tableConfig,
OverSpec overSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonCalc(ReadableConfig tableConfig,
List<org.apache.calcite.rex.RexNode> projection,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonCorrelate(ReadableConfig tableConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexCall invocation,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonGroupAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonGroupTableAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonGroupWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean generateUpdateBefore,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecPythonOverAggregate(ReadableConfig tableConfig,
OverSpec overSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecRank(ReadableConfig tableConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
RankProcessStrategy rankStrategy,
boolean outputRankNumber,
boolean generateUpdateBefore,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecSink(ReadableConfig tableConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
InputProperty inputProperty,
LogicalType outputType,
boolean upsertMaterialize,
String description) |
StreamExecSort(ReadableConfig tableConfig,
SortSpec sortSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecSortLimit(ReadableConfig tableConfig,
SortSpec sortSpec,
long limitStart,
long limitEnd,
RankProcessStrategy rankStrategy,
boolean generateUpdateBefore,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecTemporalJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
boolean isTemporalTableFunctionJoin,
int leftTimeAttributeIndex,
int rightTimeAttributeIndex,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
StreamExecTemporalSort(ReadableConfig tableConfig,
SortSpec sortSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecWatermarkAssigner(ReadableConfig tableConfig,
org.apache.calcite.rex.RexNode watermarkExpr,
int rowtimeFieldIndex,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
NamedWindowProperty[] namedWindowProperties,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecWindowDeduplicate(ReadableConfig tableConfig,
int[] partitionKeys,
int orderKey,
boolean keepLastRow,
WindowingStrategy windowing,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecWindowJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
WindowingStrategy leftWindowing,
WindowingStrategy rightWindowing,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
StreamExecWindowRank(ReadableConfig tableConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
boolean outputRankNumber,
WindowingStrategy windowing,
InputProperty inputProperty,
RowType outputType,
String description) |
StreamExecWindowTableFunction(ReadableConfig tableConfig,
TimeAttributeWindowingStrategy windowingStrategy,
InputProperty inputProperty,
RowType outputType,
String description) |
Constructor and Description |
---|
StreamExecAggregateBase(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
StreamExecCalc(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<org.apache.calcite.rex.RexNode> projection,
org.apache.calcite.rex.RexNode condition,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecChangelogNormalize(Integer id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] uniqueKeys,
boolean generateUpdateBefore,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecCorrelate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode invocation,
org.apache.calcite.rex.RexNode condition,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecDeduplicate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] uniqueKeys,
boolean isRowtime,
boolean keepLastRow,
boolean generateUpdateBefore,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecDropUpdateBefore(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecExchange(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecExpand(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<List<org.apache.calcite.rex.RexNode>> projects,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecGlobalGroupAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
RowType localAggInputRowType,
boolean generateUpdateBefore,
boolean needRetraction,
Integer indexOfCountStar,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecGlobalWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
NamedWindowProperty[] namedWindowProperties,
List<InputProperty> inputProperties,
RowType localAggInputRowType,
RowType outputType,
String description) |
StreamExecGroupAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecGroupWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecIncrementalGroupAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] partialAggGrouping,
int[] finalAggGrouping,
org.apache.calcite.rel.core.AggregateCall[] partialOriginalAggCalls,
boolean[] partialAggCallNeedRetractions,
RowType partialLocalAggInputType,
boolean partialAggNeedRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecIntervalJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
IntervalJoinSpec intervalJoinSpec,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
JoinSpec joinSpec,
List<int[]> leftUniqueKeys,
List<int[]> rightUniqueKeys,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecLimit(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
ConstantRankRange rankRange,
RankProcessStrategy rankStrategy,
boolean generateUpdateBefore,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecLocalGroupAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecLocalWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecLookupJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode joinCondition,
TemporalTableSourceSpec temporalTableSourceSpec,
Map<Integer,LookupJoinUtil.LookupKey> lookupKeys,
List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable,
org.apache.calcite.rex.RexNode filterOnTemporalTable,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecMatch(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
MatchSpec matchSpec,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecMiniBatchAssigner(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
MiniBatchInterval miniBatchInterval,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecMultipleInput(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
ExecNode<?> rootNode,
String description) |
StreamExecOverAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
OverSpec overSpec,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecPythonCalc(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<org.apache.calcite.rex.RexNode> projection,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecPythonCorrelate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
FlinkJoinType joinType,
org.apache.calcite.rex.RexNode invocation,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecPythonGroupAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
boolean[] aggCallNeedRetractions,
boolean generateUpdateBefore,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecPythonGroupWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean generateUpdateBefore,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecPythonOverAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
OverSpec overSpec,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecRank(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
RankProcessStrategy rankStrategy,
boolean outputRankNumber,
boolean generateUpdateBefore,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecSink(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
List<InputProperty> inputProperties,
LogicalType outputType,
boolean upsertMaterialize,
String description) |
StreamExecSortLimit(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
SortSpec sortSpec,
ConstantRankRange rankRange,
RankProcessStrategy rankStrategy,
boolean generateUpdateBefore,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecTemporalJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
JoinSpec joinSpec,
boolean isTemporalTableFunctionJoin,
int leftTimeAttributeIndex,
int rightTimeAttributeIndex,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecTemporalSort(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
SortSpec sortSpec,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecUnion(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecUnion(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWatermarkAssigner(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
org.apache.calcite.rex.RexNode watermarkExpr,
int rowtimeFieldIndex,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
NamedWindowProperty[] namedWindowProperties,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWindowAggregateBase(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
StreamExecWindowDeduplicate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] partitionKeys,
int orderKey,
boolean keepLastRow,
WindowingStrategy windowing,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWindowJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
JoinSpec joinSpec,
WindowingStrategy leftWindowing,
WindowingStrategy rightWindowing,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWindowRank(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
boolean outputRankNumber,
WindowingStrategy windowing,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecWindowTableFunction(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
TimeAttributeWindowingStrategy windowingStrategy,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
static String |
ExecNodeUtil.getMultipleInputDescription(ExecNode<?> rootNode,
List<ExecNode<?>> inputNodes,
List<InputProperty> inputProperties)
Return description for multiple input node.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.