Class KeyedProcessFunctionWithCleanupState<K,​IN,​OUT>

    • Field Detail

      • stateCleaningEnabled

        protected final boolean stateCleaningEnabled
    • Constructor Detail

      • KeyedProcessFunctionWithCleanupState

        public KeyedProcessFunctionWithCleanupState​(long minRetentionTime,
                                                    long maxRetentionTime)
    • Method Detail

      • initCleanupTimeState

        protected void initCleanupTimeState​(String stateName)
      • registerProcessingCleanupTimer

        protected void registerProcessingCleanupTimer​(org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context ctx,
                                                      long currentTime)
                                               throws Exception
        Throws:
        Exception
      • isProcessingTimeTimer

        protected boolean isProcessingTimeTimer​(org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext ctx)
      • cleanupState

        protected void cleanupState​(org.apache.flink.api.common.state.State... states)