Uses of Class
org.apache.flink.table.planner.plan.logical.WindowingStrategy
-
Packages that use WindowingStrategy Package Description org.apache.flink.table.planner.plan.logical org.apache.flink.table.planner.plan.nodes.exec.stream -
-
Uses of WindowingStrategy in org.apache.flink.table.planner.plan.logical
Subclasses of WindowingStrategy in org.apache.flink.table.planner.plan.logical Modifier and Type Class Description class
SliceAttachedWindowingStrategy
A windowing strategy that gets windows from input columns as window slice have been assigned and attached to the physical columns.class
TimeAttributeWindowingStrategy
A windowing strategy that gets windows by calculating on time attribute column.class
WindowAttachedWindowingStrategy
A windowing strategy that gets windows from input columns as windows have been assigned and attached to the physical columns. -
Uses of WindowingStrategy in org.apache.flink.table.planner.plan.nodes.exec.stream
Methods in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type WindowingStrategy Modifier and Type Method Description protected WindowAssigner
StreamExecWindowAggregateBase. createWindowAssigner(WindowingStrategy windowingStrategy, ZoneId shiftTimeZone)
Constructors in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type WindowingStrategy Constructor Description StreamExecGlobalWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, List<InputProperty> inputProperties, RowType localAggInputRowType, RowType outputType, String description)
StreamExecGlobalWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType localAggInputRowType, RowType outputType, String description)
StreamExecLocalWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLocalWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, Boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType 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)
StreamExecWindowDeduplicate(ReadableConfig tableConfig, int[] partitionKeys, int orderKey, boolean keepLastRow, WindowingStrategy windowing, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, WindowingStrategy leftWindowing, WindowingStrategy rightWindowing, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowJoin(ReadableConfig tableConfig, JoinSpec joinSpec, WindowingStrategy leftWindowing, WindowingStrategy rightWindowing, InputProperty leftInputProperty, InputProperty rightInputProperty, 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)
StreamExecWindowRank(ReadableConfig tableConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, boolean outputRankNumber, WindowingStrategy windowing, InputProperty inputProperty, RowType outputType, String description)
-