T
- The message type for pulsar decoded message.@Internal public class PulsarUnorderedFetcherManager<T> extends PulsarFetcherManagerBase<T>
Consumer
inside the PulsarUnorderedPartitionSplitReader
.fetchers
Constructor and Description |
---|
PulsarUnorderedFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue,
java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier) |
Modifier and Type | Method and Description |
---|---|
List<PulsarPartitionSplit> |
snapshotState() |
addSplits, getOrCreateFetcher, startFetcher
checkErrors, close, createSplitFetcher, getNumAliveFetchers, maybeShutdownFinishedFetchers
public PulsarUnorderedFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue, java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier)
public List<PulsarPartitionSplit> snapshotState()
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.