Class SnapshotUtils


  • @Internal
    public final class SnapshotUtils
    extends Object
    Takes a final snapshot of the state of an operator subtask.
    • Method Summary

      All Methods Static Methods Concrete Methods 
      Modifier and Type Method Description
      static <OUT,​OP extends org.apache.flink.streaming.api.operators.StreamOperator<OUT>>
      TaggedOperatorSubtaskState
      snapshot​(OP operator, int index, long timestamp, boolean isExactlyOnceMode, boolean isUnalignedCheckpoint, org.apache.flink.configuration.Configuration configuration, org.apache.flink.core.fs.Path savepointPath)  
      static <OUT,​OP extends org.apache.flink.streaming.api.operators.StreamOperator<OUT>>
      TaggedOperatorSubtaskState
      snapshot​(OP operator, int index, long timestamp, boolean isExactlyOnceMode, boolean isUnalignedCheckpoint, org.apache.flink.configuration.Configuration configuration, org.apache.flink.core.fs.Path savepointPath, org.apache.flink.core.execution.SavepointFormatType savepointFormatType)  
    • Method Detail

      • snapshot

        public static <OUT,​OP extends org.apache.flink.streaming.api.operators.StreamOperator<OUT>> TaggedOperatorSubtaskState snapshot​(OP operator,
                                                                                                                                              int index,
                                                                                                                                              long timestamp,
                                                                                                                                              boolean isExactlyOnceMode,
                                                                                                                                              boolean isUnalignedCheckpoint,
                                                                                                                                              org.apache.flink.configuration.Configuration configuration,
                                                                                                                                              org.apache.flink.core.fs.Path savepointPath,
                                                                                                                                              org.apache.flink.core.execution.SavepointFormatType savepointFormatType)
                                                                                                                                       throws Exception
        Throws:
        Exception
      • snapshot

        public static <OUT,​OP extends org.apache.flink.streaming.api.operators.StreamOperator<OUT>> TaggedOperatorSubtaskState snapshot​(OP operator,
                                                                                                                                              int index,
                                                                                                                                              long timestamp,
                                                                                                                                              boolean isExactlyOnceMode,
                                                                                                                                              boolean isUnalignedCheckpoint,
                                                                                                                                              org.apache.flink.configuration.Configuration configuration,
                                                                                                                                              org.apache.flink.core.fs.Path savepointPath)
                                                                                                                                       throws Exception
        Throws:
        Exception