public static class FileTierPartitionState.State extends Object
Modifier and Type | Field and Description |
---|---|
Consumer<TierPartitionState.RecoveryOperation> |
recoveryWorkflowCb |
public Consumer<TierPartitionState.RecoveryOperation> recoveryWorkflowCb
public void updateBasePath(String path)
public void beginCatchup()
public void onCatchUpComplete()
public void beginDiscover()
public void onDiscoverComplete()
public Long endOffset()
public Long dataEndOffset()
public int numSegments()
public long compactDirtyStartOffset()
public CompactStats lastCompactStats()
public CompactStats accumulatedCompactStats()
public NavigableSet<Long> segmentOffsets(long from, long to)
public Collection<SegmentState> segments()
public Collection<SegmentState> segments(long from, long to)
public List<SegmentState> fetchInMemoryMetadataRange(long from, long to)
from
- Inclusive startOffset positionto
- Inclusive startOffset positionpublic Optional<SegmentState> previousMetadataBeforeOffset(long targetStartOffset)
targetStartOffset
- target startOffsetpublic Optional<SegmentState> metadata(long targetOffset) throws IOException
IOException
public CompletableFuture<Optional<kafka.log.TierLogSegment>> materializeUptoLeaderEpoch(int targetEpoch) throws IOException
FileTierPartitionState.materializeUptoLeaderEpoch(int)
for usage.IOException
public CompletableFuture<kafka.log.TierLogSegment> materializationListener(long targetOffset) throws IOException
FileTierPartitionState.materializeUptoOffset(long)
for usage.IOException
public CompletableFuture<kafka.log.TierLogSegment> materializationListener(long upperBoundEndOffset, UUID targetObjectId, long targetRestoreEpoch) throws IOException
IOException
public CompletableFuture<Boolean> trackMetadataInitialization(int targetLeaderEpoch) throws IllegalStateException, IOException
FileTierPartitionState.trackMetadataInitialization(int)
for usage.IllegalStateException
IOException
public void maybeRemoveErrorFile() throws IOException
IOException
public static long appendWithSizePrefixStatic(ByteBuffer metadataBuffer, CheckedFileIO channel) throws IOException
IOException