Package | Description |
---|---|
org.apache.flink.table.runtime.operators.aggregate.window.processors | |
org.apache.flink.table.runtime.operators.window.tvf.unslicing |
Modifier and Type | Field and Description |
---|---|
protected MergingWindowProcessFunction<RowData,TimeWindow> |
UnsliceWindowAggProcessor.windowFunction |
Modifier and Type | Method and Description |
---|---|
Optional<TimeWindow> |
UnsliceAssigners.SessionUnsliceAssigner.assignActualWindow(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,TimeWindow> windowFunction) |
Optional<TimeWindow> |
UnsliceAssigners.WindowedUnsliceAssigner.assignActualWindow(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,TimeWindow> windowFunction) |
Optional<W> |
UnsliceAssigner.assignActualWindow(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,W> windowFunction)
Returns the
Window that the given element should belong to be used to trigger on. |
Optional<TimeWindow> |
UnsliceAssigners.SessionUnsliceAssigner.assignStateNamespace(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,TimeWindow> windowFunction) |
Optional<TimeWindow> |
UnsliceAssigners.WindowedUnsliceAssigner.assignStateNamespace(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,TimeWindow> windowFunction) |
Optional<W> |
UnsliceAssigner.assignStateNamespace(RowData element,
ClockService clock,
MergingWindowProcessFunction<?,W> windowFunction)
Returns the
Window that the given element should belong to be used as a namespace to
restore the state. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.