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. exclusivePhysicalFilePool
Queue maintaining exclusive physical files for reusing.protected Map<FileMergingSnapshotManager.SubtaskKey,Queue<PhysicalFile>>
PhysicalFilePool. sharedPhysicalFilePoolBySubtask
Map 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 PhysicalFile
FileMergingSnapshotManagerBase. 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 PhysicalFile
AcrossCheckpointFileMergingSnapshotManager. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointID, CheckpointedStateScope scope)
protected abstract PhysicalFile
FileMergingSnapshotManagerBase. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, CheckpointedStateScope scope)
Get a reused physical file or create one.protected PhysicalFile
WithinCheckpointFileMergingSnapshotManager. getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, CheckpointedStateScope scope)
PhysicalFile
LogicalFile. getPhysicalFile()
PhysicalFile
PhysicalFile.PhysicalFileCreator. perform(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)
Create the file.PhysicalFile
BlockingPhysicalFilePool. pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)
PhysicalFile
NonBlockingPhysicalFilePool. pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, CheckpointedStateScope scope)
abstract PhysicalFile
PhysicalFilePool. 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 LogicalFile
FileMergingSnapshotManagerBase. createLogicalFile(PhysicalFile physicalFile, long startOffset, long length, FileMergingSnapshotManager.SubtaskKey subtaskKey)
Create a logical file on a physical file.protected void
AcrossCheckpointFileMergingSnapshotManager. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)
protected abstract void
FileMergingSnapshotManagerBase. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)
Try to return an existing physical file to the manager for next reuse.protected void
WithinCheckpointFileMergingSnapshotManager. returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey, long checkpointId, PhysicalFile physicalFile)
boolean
BlockingPhysicalFilePool. tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, PhysicalFile physicalFile)
boolean
NonBlockingPhysicalFilePool. tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey, PhysicalFile physicalFile)
abstract boolean
PhysicalFilePool. 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)
-