public class TierStateFetcher extends Object
Modifier and Type | Field and Description |
---|---|
static Integer |
ESTIMATED_BUFFER_SIZE |
Constructor and Description |
---|
TierStateFetcher(Integer numThreads,
TierObjectStore tierObjectStore) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
CompletableFuture<List<org.apache.kafka.storage.internals.log.EpochEntry>> |
fetchLeaderEpochStateAsync(TierObjectStore.ObjectMetadata metadata)
Send a request to the tier state fetcher executor, returning a future that will be
completed when the request has read the tier state from the object store.
|
CompletableFuture<ByteBuffer> |
fetchProducerStateSnapshotAsync(TierObjectStore.ObjectMetadata metadata) |
ByteBuffer |
fetchRecoverSnapshot(TierObjectStore.TierStateRestoreSnapshotMetadata metadata) |
ByteBuffer |
fetchTierPartitionStateSnapshot(TierObjectStore.TierPartitionStateSnapshotMetadata metadata) |
public static final Integer ESTIMATED_BUFFER_SIZE
public TierStateFetcher(Integer numThreads, TierObjectStore tierObjectStore)
public void close()
public CompletableFuture<List<org.apache.kafka.storage.internals.log.EpochEntry>> fetchLeaderEpochStateAsync(TierObjectStore.ObjectMetadata metadata)
metadata
- the tier object metadata for this tier state.public CompletableFuture<ByteBuffer> fetchProducerStateSnapshotAsync(TierObjectStore.ObjectMetadata metadata)
public ByteBuffer fetchRecoverSnapshot(TierObjectStore.TierStateRestoreSnapshotMetadata metadata) throws IOException
IOException
public ByteBuffer fetchTierPartitionStateSnapshot(TierObjectStore.TierPartitionStateSnapshotMetadata metadata) throws IOException
IOException