T
- The decoded message type for flink.@Internal public abstract class PulsarFetcherManagerBase<T> extends SplitFetcherManager<PulsarMessage<T>,PulsarPartitionSplit>
fetchers
Modifier | Constructor and Description |
---|---|
protected |
PulsarFetcherManagerBase(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue,
java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier)
Creates a new SplitFetcherManager with multiple I/O threads.
|
Modifier and Type | Method and Description |
---|---|
void |
addSplits(List<PulsarPartitionSplit> splitsToAdd)
Override this method for supporting multiple thread fetching, one fetcher thread for one
split.
|
protected SplitFetcher<PulsarMessage<T>,PulsarPartitionSplit> |
getOrCreateFetcher(String splitId) |
protected void |
startFetcher(SplitFetcher<PulsarMessage<T>,PulsarPartitionSplit> fetcher) |
checkErrors, close, createSplitFetcher, getNumAliveFetchers, maybeShutdownFinishedFetchers
protected PulsarFetcherManagerBase(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue, java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier)
elementsQueue
- The queue that is used to hand over data from the I/O thread (the
fetchers) to the reader (which emits the records and book-keeps the state. This must be
the same queue instance that is also passed to the SourceReaderBase
.splitReaderSupplier
- The factory for the split reader that connects to the sourcepublic void addSplits(List<PulsarPartitionSplit> splitsToAdd)
addSplits
in class SplitFetcherManager<PulsarMessage<T>,PulsarPartitionSplit>
protected void startFetcher(SplitFetcher<PulsarMessage<T>,PulsarPartitionSplit> fetcher)
startFetcher
in class SplitFetcherManager<PulsarMessage<T>,PulsarPartitionSplit>
protected SplitFetcher<PulsarMessage<T>,PulsarPartitionSplit> getOrCreateFetcher(String splitId)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.