Interface CleanupState
-
- All Known Implementing Classes:
AbstractRowTimeUnboundedPrecedingOver
,KeyedProcessFunctionWithCleanupState
,ProcTimeRowsBoundedPrecedingFunction
,RowTimeRangeUnboundedPrecedingFunction
,RowTimeRowsBoundedPrecedingFunction
,RowTimeRowsUnboundedPrecedingFunction
public interface CleanupState
Base interface for clean up state, both forProcessFunction
andCoProcessFunction
.
-
-
Method Summary
All Methods Instance Methods Default Methods Modifier and Type Method Description default void
registerProcessingCleanupTimer(org.apache.flink.api.common.state.ValueState<Long> cleanupTimeState, long currentTime, long minRetentionTime, long maxRetentionTime, org.apache.flink.streaming.api.TimerService timerService)
-
-
-
Method Detail
-
registerProcessingCleanupTimer
default void registerProcessingCleanupTimer(org.apache.flink.api.common.state.ValueState<Long> cleanupTimeState, long currentTime, long minRetentionTime, long maxRetentionTime, org.apache.flink.streaming.api.TimerService timerService) throws Exception
- Throws:
Exception
-
-