FileMergingCheckpointStateOutputStream |
FileMergingSnapshotManager.createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
|
FileMergingCheckpointStateOutputStream |
FileMergingSnapshotManagerBase.createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
|
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 Queue<PhysicalFile> |
PhysicalFilePool.getFileQueue(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
Get or create a file queue for specific subtaskKey and checkpoint scope.
|
org.apache.flink.core.fs.Path |
FileMergingSnapshotManager.getManagedDir(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
org.apache.flink.core.fs.Path |
FileMergingSnapshotManagerBase.getManagedDir(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
DirectoryStreamStateHandle |
FileMergingSnapshotManager.getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
DirectoryStreamStateHandle |
FileMergingSnapshotManagerBase.getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
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 |
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.
|