Constructor and Description |
---|
PendingFetch(CancellationContext cancellationContext,
TierObjectStore tierObjectStore,
FetchOffsetCache cache,
Optional<kafka.tier.fetcher.TierFetcherMetrics> tierFetcherMetrics,
TierObjectStore.ObjectMetadata objectMetadata,
Consumer<kafka.server.DelayedOperationKey> fetchCompletionCallback,
long targetOffset,
int maxBytes,
int segmentSize,
org.apache.kafka.common.IsolationLevel isolationLevel,
MemoryTracker memoryTracker,
List<org.apache.kafka.common.TopicPartition> ignoredTopicPartitions,
org.apache.kafka.common.utils.Time time) |
Modifier and Type | Method and Description |
---|---|
void |
cancel()
Cancel the pending fetch.
|
List<kafka.server.DelayedOperationKey> |
delayedOperationKeys()
Generate DelayedFetch purgatory operation keys
|
Map<org.apache.kafka.common.TopicPartition,TierFetchResult> |
finish()
Block on a fetch request finishing (or canceling), returning either complete MemoryRecords
for the fetch, or empty records.
|
boolean |
isComplete()
Checks if the pending fetch has finished
|
void |
markFetchExpired() |
void |
run() |
public PendingFetch(CancellationContext cancellationContext, TierObjectStore tierObjectStore, FetchOffsetCache cache, Optional<kafka.tier.fetcher.TierFetcherMetrics> tierFetcherMetrics, TierObjectStore.ObjectMetadata objectMetadata, Consumer<kafka.server.DelayedOperationKey> fetchCompletionCallback, long targetOffset, int maxBytes, int segmentSize, org.apache.kafka.common.IsolationLevel isolationLevel, MemoryTracker memoryTracker, List<org.apache.kafka.common.TopicPartition> ignoredTopicPartitions, org.apache.kafka.common.utils.Time time)
public List<kafka.server.DelayedOperationKey> delayedOperationKeys()
public boolean isComplete()
public Map<org.apache.kafka.common.TopicPartition,TierFetchResult> finish()
public void markFetchExpired()
public void cancel()