Interface FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy

    • Method Detail

      • providePhysicalFile

        org.apache.flink.api.java.tuple.Tuple2<org.apache.flink.core.fs.FSDataOutputStream,​org.apache.flink.core.fs.Path> providePhysicalFile()
                                                                                                                                             throws IOException
        Provide a physical file.
        Returns:
        Output stream and path of the physical file.
        Throws:
        IOException - if the physical file cannot be created or opened.
      • closeStreamAndCreateStateHandle

        SegmentFileStateHandle closeStreamAndCreateStateHandle​(org.apache.flink.core.fs.Path filePath,
                                                               long startPos,
                                                               long stateSize)
                                                        throws IOException
        Close the stream and create a SegmentFileStateHandle for a file segment.
        Parameters:
        filePath - Path of the physical file.
        startPos - Start position of the segment in the physical file.
        stateSize - Size of the segment.
        Returns:
        The state handle of the segment.
        Throws:
        IOException - if any exception happens when closing the file.