Uses of Class
org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
-
Packages that use PhysicalFile Package Description org.apache.flink.runtime.checkpoint.filemerging -
-
Uses of PhysicalFile in org.apache.flink.runtime.checkpoint.filemerging
Fields in org.apache.flink.runtime.checkpoint.filemerging with type parameters of type PhysicalFile Modifier and Type Field Description protected Queue<PhysicalFile>PhysicalFilePool. exclusivePhysicalFilePoolQueue maintaining exclusive physical files for reusing.protected Map<FileMergingSnapshotManager.SubtaskKey,Queue<PhysicalFile>>PhysicalFilePool. sharedPhysicalFilePoolBySubtaskMap maintaining queues of different subtasks for reusing shared physical files.Methods in org.apache.flink.runtime.checkpoint.filemerging that return PhysicalFile Modifier and Type Method Description protected PhysicalFileFileMergingSnapshotManagerBase. createPhysicalFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)Create a physical file in right location (managed directory), which is specified by scope of this checkpoint and current subtask.protected PhysicalFileAcrossCheckpointFileMergingSnapshotManager. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointID, CheckpointedStateScope scope)protected abstract PhysicalFileFileMergingSnapshotManagerBase. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, CheckpointedStateScope scope)Get a reused physical file or create one.protected PhysicalFileWithinCheckpointFileMergingSnapshotManager. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, CheckpointedStateScope scope)PhysicalFileLogicalFile. getPhysicalFile()PhysicalFilePhysicalFile.PhysicalFileCreator. perform(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)Create the file.PhysicalFileBlockingPhysicalFilePool. pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)PhysicalFileNonBlockingPhysicalFilePool. pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)abstract PhysicalFilePhysicalFilePool. pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)Poll a physical file from the pool.Methods in org.apache.flink.runtime.checkpoint.filemerging that return types with arguments of type PhysicalFile Modifier and Type Method Description protected Queue<PhysicalFile>BlockingPhysicalFilePool. createFileQueue()protected Queue<PhysicalFile>NonBlockingPhysicalFilePool. createFileQueue()protected abstract Queue<PhysicalFile>PhysicalFilePool. createFileQueue()Create and return a file queue.protected Queue<PhysicalFile>PhysicalFilePool. getFileQueue(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)Get or create a file queue for specific subtaskKey and checkpoint scope.Methods in org.apache.flink.runtime.checkpoint.filemerging with parameters of type PhysicalFile Modifier and Type Method Description protected LogicalFileFileMergingSnapshotManagerBase. createLogicalFile(PhysicalFile physicalFile, long startOffset, long length, FileMergingSnapshotManager.SubtaskKey subtaskKey)Create a logical file on a physical file.protected voidAcrossCheckpointFileMergingSnapshotManager. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)protected abstract voidFileMergingSnapshotManagerBase. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)Try to return an existing physical file to the manager for next reuse.protected voidWithinCheckpointFileMergingSnapshotManager. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)booleanBlockingPhysicalFilePool. tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, PhysicalFile physicalFile)booleanNonBlockingPhysicalFilePool. tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, PhysicalFile physicalFile)abstract booleanPhysicalFilePool. tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, PhysicalFile physicalFile)Try to put a physical file into file pool.Constructors in org.apache.flink.runtime.checkpoint.filemerging with parameters of type PhysicalFile Constructor Description LogicalFile(LogicalFile.LogicalFileId fileId, PhysicalFile physicalFile, long startOffset, long length, FileMergingSnapshotManager.SubtaskKey subtaskKey)
-