Index

A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ABORT - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
abortTransaction() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
AbstractOffsetCommitter<K,V> - Class in io.confluent.parallelconsumer.internal
 
AbstractOffsetCommitter(ConsumerManager<K, V>, WorkManager<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
AbstractParallelEoSStreamProcessor<K,V> - Class in io.confluent.parallelconsumer.internal
 
AbstractParallelEoSStreamProcessor(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
AbstractParallelEoSStreamProcessor(ParallelConsumerOptions<K, V>, PCModule<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Construct the AsyncConsumer by wrapping this passed in conusmer and producer, which can be configured any which way as per normal.
acquireProduceLock(PollContextInternal<K, V>) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
addLoopEndCallBack(Runnable) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Plugin a function to run at the end of each main loop.
addToMailbox(PollContextInternal<K, V>, WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
addToMailBoxOnUserFunctionSuccess(PollContextInternal<K, V>, WorkContainer<K, V>, List<?>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
addToMailBoxOnUserFunctionSuccess(PollContextInternal<K, V>, WorkContainer<K, V>, List<?>) - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
With Vertx and Reactor, a function hasn't succeeded until the inner vertx function has also succeeded no op
addWorkContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
addWorkContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
addWorkContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
addWorkContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
addWorkContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.ShardManager
 
allowEagerProcessingDuringTransactionCommit - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
allowEagerProcessingDuringTransactionCommit(boolean) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
When using ParallelConsumerOptions.CommitMode.PERIODIC_TRANSACTIONAL_PRODUCER, allows new records to be processed UP UNTIL the result record SENDING (Producer.send(org.apache.kafka.clients.producer.ProducerRecord<K, V>)) step, potentially while a transaction is being committed.
assignment() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 

B

BackportUtils - Class in io.confluent.csid.utils
 
BackportUtils() - Constructor for class io.confluent.csid.utils.BackportUtils
 
batchSize - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
batchSize(Integer) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
The maximum number of messages to attempt to pass into the user functions.
BEGIN - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
beginProducing(PollContextInternal<K, V>) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
Must call before sending records - acquires the lock on sending records, which blocks committing transactions)
beginTransaction() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
BitSet - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
BitSetCompressed - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
BitSetEncoder - Class in io.confluent.parallelconsumer.offsets
Encodes a range of offsets, from an incompletes collection into a BitSet.
BitSetEncoder(int, OffsetSimultaneousEncoder) - Constructor for class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
BitSetEncoder(int, OffsetSimultaneousEncoder, OffsetEncoding.Version) - Constructor for class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
BitSetEncodingNotSupportedException - Exception in io.confluent.parallelconsumer.offsets
 
BitSetEncodingNotSupportedException(String) - Constructor for exception io.confluent.parallelconsumer.offsets.BitSetEncodingNotSupportedException
 
BitSetV2 - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
switch from encoding bitset length as a short to an integer (length of 32,000 was reasonable too short)
BitSetV2Compressed - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
brokerPoller(AbstractParallelEoSStreamProcessor<K, V>) - Method in class io.confluent.parallelconsumer.internal.PCModule
 
BrokerPollSystem<K,V> - Class in io.confluent.parallelconsumer.internal
Subsystem for polling the broker for messages.
BrokerPollSystem(ConsumerManager<K, V>, WorkManager<K, V>, AbstractParallelEoSStreamProcessor<K, V>, ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.BrokerPollSystem
 
build() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult.TimeResultBuilder
 
build() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
 
build() - Method in class io.confluent.parallelconsumer.RecordContext.RecordContextBuilder
 
build(KKEY, Map<KKEY, VVALUE>) - Static method in class io.confluent.csid.utils.LoopingResumingIterator
 
builder() - Static method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
builder() - Static method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
builder() - Static method in class io.confluent.parallelconsumer.RecordContext
 
ByteArray - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
ByteArrayCompressed - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
ByteBufferEncoder - Class in io.confluent.parallelconsumer.offsets
 
ByteBufferEncoder(int, OffsetSimultaneousEncoder) - Constructor for class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 

C

calculateQuantityToRequest() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
calculateSucceededActualOffsets(long) - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.PollContext
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.RecordContext
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
canEqual(Object) - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
carefullyRun(BiFunction<PARAM_ONE, PARAM_TWO, RESULT>, PARAM_ONE, PARAM_TWO) - Static method in class io.confluent.parallelconsumer.internal.UserFunctions
 
carefullyRun(Consumer<PARAM>, PARAM) - Static method in class io.confluent.parallelconsumer.internal.UserFunctions
 
carefullyRun(Function<PARAM, RESULT>, PARAM) - Static method in class io.confluent.parallelconsumer.internal.UserFunctions
 
CHARSET_TO_USE - Static variable in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
 
checkIfWorkIsStale(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Have our partitions been revoked?
checkIfWorkIsStale(List<WorkContainer<K, V>>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Have our partitions been revoked? Can a batch contain messages of different epochs?
checkPipelinePressure() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Checks the system has enough pressure in the pipeline of work, if not attempts to step up the load factor.
checkPipelinePressure() - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
 
claim() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter
 
clock() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
close() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Close the system, without draining.
close() - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
Close the consumer, without draining.
close() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
close(Duration) - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
close(Duration) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
Assumes the system is drained at this point, or draining is not desired.
close(Duration) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
close(Duration, DrainingCloseable.DrainingMode) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
close(Duration, DrainingCloseable.DrainingMode) - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
Close the consumer.
CLOSE - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
closeAndWait() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
 
closed - Enum constant in enum class io.confluent.parallelconsumer.internal.State
 
closeDontDrainFirst() - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
 
closeDontDrainFirst(Duration) - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
 
closeDrainFirst() - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
 
closeDrainFirst(Duration) - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
 
closing - Enum constant in enum class io.confluent.parallelconsumer.internal.State
 
collectCommitDataForDirtyPartitions() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
collectDirtyCommitData() - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
COMMIT - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
commitInterval - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
commitInterval(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Time between commits.
commitLockAcquisitionTimeout - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
commitLockAcquisitionTimeout(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Time to allow for acquiring the commit lock.
commitMode - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
commitMode(ParallelConsumerOptions.CommitMode) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
commitOffsets(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
commitOffsets(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
commitOffsets(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter
 
commitOffsetsThatAreReady() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Visible for testing
CommitRequest() - Constructor for class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
CommitResponse(ConsumerOffsetCommitter.CommitRequest) - Constructor for class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitResponse
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
commitTransaction() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
compareTo(EncodedOffsetPair) - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
compareTo(WorkContainer) - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
COMPRESSION_FORCED_RESOURCE_LOCK - Static variable in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Used to prevent tests running in parallel that depends on setting static state in this class.
compressionForced - Static variable in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Force the encoder to also add the compressed versions.
ConsumeProduceResult(PollContext<K, V>, ProducerRecord<KK, VV>, RecordMetadata) - Constructor for class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
consumer - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
consumer() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
consumer(Consumer<K, V>) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Required parameter for all use.
consumerManager() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
ConsumerManager<K,V> - Class in io.confluent.parallelconsumer.internal
Delegate for KafkaConsumer
ConsumerManager(Consumer<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.ConsumerManager
 
consumerMgr - Variable in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
ConsumerOffsetCommitter<K,V> - Class in io.confluent.parallelconsumer.internal
Committer that uses the Kafka Consumer to commit either synchronously or asynchronously
ConsumerOffsetCommitter(ConsumerManager<K, V>, WorkManager<K, V>, ParallelConsumerOptions) - Constructor for class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter
 
ConsumerOffsetCommitter.CommitRequest - Class in io.confluent.parallelconsumer.internal
Commit request message
ConsumerOffsetCommitter.CommitResponse - Class in io.confluent.parallelconsumer.internal
Commit response message, linked to a ConsumerOffsetCommitter.CommitRequest
consumerRecord(ConsumerRecord<K, V>) - Method in class io.confluent.parallelconsumer.RecordContext.RecordContextBuilder
 
ConsumerRecordId - Class in io.confluent.parallelconsumer.state
Useful identifier for a ConsumerRecord.
ConsumerRecordId(TopicPartition, long) - Constructor for class io.confluent.parallelconsumer.state.ConsumerRecordId
 
controlLoop(Function<PollContextInternal<K, V>, List<R>>, Consumer<R>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Main control loop
couldBeTakenAsWork(WorkContainer<?, ?>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
couldPerform() - Method in class io.confluent.parallelconsumer.internal.RateLimiter
 
count() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
The number of records for all topics
createEosStreamProcessor(ParallelConsumerOptions<KK, VV>) - Static method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
 
createJStreamEosStreamProcessor(ParallelConsumerOptions<?, ?>) - Static method in interface io.confluent.parallelconsumer.JStreamParallelStreamProcessor
 

D

decode(byte) - Static method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
DEFAULT_COMMIT_INTERVAL - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
DEFAULT_COMMIT_INTERVAL_FOR_TRANSACTIONS - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
DEFAULT_MAX_CONCURRENCY - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
DEFAULT_STATIC_RETRY_DELAY - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
DEFAULT_TIMEOUT - Static variable in interface io.confluent.parallelconsumer.internal.DrainingCloseable
 
DefaultMaxMetadataSize - Static variable in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
Maximum size of the commit offset metadata
defaultMessageRetryDelay - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
defaultMessageRetryDelay(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Deprecated.
will be renamed to static retry delay
description() - Method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
deserialiseIncompleteOffsetMapFromBase64(long, String) - Static method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
 
DOCS_ROOT - Static variable in class io.confluent.parallelconsumer.internal.Documentation
 
Documentation - Class in io.confluent.parallelconsumer.internal
 
Documentation() - Constructor for class io.confluent.parallelconsumer.internal.Documentation
 
DONT_DRAIN - Enum constant in enum class io.confluent.parallelconsumer.internal.DrainingCloseable.DrainingMode
Stop downloading more messages, and stop procesing more messages in the queue, but finish processing messages already being processed locally.
drain() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Will begin the shutdown process, eventually closing itself once drained
DRAIN - Enum constant in enum class io.confluent.parallelconsumer.internal.DrainingCloseable.DrainingMode
Stop downloading more messages from the Broker, but finish processing what has already been queued.
draining - Enum constant in enum class io.confluent.parallelconsumer.internal.State
When draining, the system will stop polling for more records, but will attempt to process all already downloaded records.
DrainingCloseable - Interface in io.confluent.parallelconsumer.internal
 
DrainingCloseable.DrainingMode - Enum Class in io.confluent.parallelconsumer.internal
 
dynamicExtraLoadFactor - Variable in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Multiple of ParallelConsumerOptions.getMaxConcurrency() to have in our processing queue, in order to make sure threads always have work to do.
dynamicExtraLoadFactor() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
DynamicLoadFactor - Class in io.confluent.parallelconsumer.internal
Controls a loading factor.
DynamicLoadFactor() - Constructor for class io.confluent.parallelconsumer.internal.DynamicLoadFactor
 

E

encodeCompletedOffset(int) - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
encodeCompletedOffset(int) - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
encodeCompletedOffset(int) - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
EncodedOffsetPair - Class in io.confluent.parallelconsumer.offsets
 
encodeIncompleteOffset(int) - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
encodeIncompleteOffset(int) - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
encodeIncompleteOffset(int) - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
EncodingNotSupportedException - Exception in io.confluent.parallelconsumer.offsets
 
EncodingNotSupportedException(String) - Constructor for exception io.confluent.parallelconsumer.offsets.EncodingNotSupportedException
 
endFlight() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
endMs(long) - Method in class io.confluent.csid.utils.TimeUtils.TimeResult.TimeResultBuilder
 
EpochAndRecordsMap<K,V> - Class in io.confluent.parallelconsumer.internal
For tagging polled records with our epoch
EpochAndRecordsMap(ConsumerRecords<K, V>, PartitionStateManager<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
 
EpochAndRecordsMap.RecordsAndEpoch - Class in io.confluent.parallelconsumer.internal
 
equals(Object) - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
equals(Object) - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
equals(Object) - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitResponse
 
equals(Object) - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
 
equals(Object) - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
equals(Object) - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
equals(Object) - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
equals(Object) - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
equals(Object) - Method in class io.confluent.parallelconsumer.PollContext
 
equals(Object) - Method in class io.confluent.parallelconsumer.RecordContext
 
equals(Object) - Method in class io.confluent.parallelconsumer.state.ConsumerRecordId
 
equals(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey
 
equals(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 
equals(Object) - Method in class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
equals(Object) - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
ExceptionInUserFunctionException - Exception in io.confluent.parallelconsumer
This exception is only used when there is an exception thrown from code provided by the user.
ExceptionInUserFunctionException() - Constructor for exception io.confluent.parallelconsumer.ExceptionInUserFunctionException
 
ExternalEngine<K,V> - Class in io.confluent.parallelconsumer.internal
Overrides key aspects required in common for other threading engines like Vert.x and Reactor
ExternalEngine(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.ExternalEngine
 

F

Fields() - Constructor for class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
finishProducing(ProducerManager.ProducingLock) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
Must call after finishing sending records - unlocks the produce lock to potentially unblock transaction committing.
flush() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
forcedCodec - Static variable in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
Forces the use of a specific codec, instead of choosing the most efficient one.
forEach(Consumer<? super RecordContext<K, V>>) - Method in class io.confluent.parallelconsumer.PollContext
 
forEach(Consumer<? super RecordContext<K, V>>) - Method in class io.confluent.parallelconsumer.PollContextInternal
 

G

getAllIncompleteOffsets() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
getBatchSize() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
The maximum number of messages to attempt to pass into the user functions.
getBitSet() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
getByTopicPartitionMap() - Method in class io.confluent.parallelconsumer.PollContext
 
getByTopicPartitionMap() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getClock() - Static method in class io.confluent.csid.utils.TimeUtils
 
getCommitDataIfDirty() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
getCommitInterval() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Time between commits.
getCommitLockAcquisitionTimeout() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Time to allow for acquiring the commit lock.
getCommitMode() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
getCommitQueueSize() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
getCommitQueueSize() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getConsumer() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Required parameter for all use.
getConsumerRecord() - Method in class io.confluent.parallelconsumer.RecordContext
 
getConsumerRecordsFlattened() - Method in class io.confluent.parallelconsumer.PollContext
 
getConsumerRecordsFlattened() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getContextsFlattened() - Method in class io.confluent.parallelconsumer.PollContext
 
getContextsFlattened() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getCountOfWorkAwaitingSelection() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
getCountOfWorkTracked() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
getCountWorkInFlight() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
getCr() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getCurrentFactor() - Method in class io.confluent.parallelconsumer.internal.DynamicLoadFactor
 
getData() - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
getDecodedIncompletes(long) - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
getDecodedString() - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
getDefaultMessageRetryDelay() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Deprecated.
will be renamed to static retry delay
getDelayUntilRetryDue() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getElapsed() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
getElapsedDuration() - Method in class io.confluent.parallelconsumer.internal.RateLimiter
 
getEncodedBytes() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
getEncodedBytes() - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
getEncodedBytes() - Method in class io.confluent.parallelconsumer.offsets.OffsetEncoder
 
getEncodedBytes() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
getEncodedSize() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
getEncodedSize() - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
getEncodedSize() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
getEncoding() - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
getEncodingMap() - Method in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Map of different encoding types for the same offset data, used for retrieving the data for the encoding type
getEncodingType() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
getEncodingType() - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
getEncodingType() - Method in class io.confluent.parallelconsumer.offsets.OffsetEncoder
 
getEncodingType() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
getEncodingTypeCompressed() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
getEncodingTypeCompressed() - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
getEncodingTypeCompressed() - Method in class io.confluent.parallelconsumer.offsets.OffsetEncoder
 
getEncodingTypeCompressed() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
getEndMs() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
getEntries() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
Map of offset to WorkUnits.
getEpoch() - Method in class io.confluent.parallelconsumer.state.WorkContainer
Assignment generation this record comes from.
getEpochOfPartition(TopicPartition) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
getEpochOfPartitionAtPoll() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
getEpochOfPartitionForRecord(ConsumerRecord<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
getFailureCause() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getFuture() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getHighestSeenOffset() - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
The highest represented offset in this result.
getHighestSeenOffset(TopicPartition) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
getId() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
getIn() - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
getIncompleteOffsets() - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
Of the offsets encoded, the incomplete ones.
getIncompleteOffsets() - Method in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
The offsets which have not yet been fully completed and can't have their offset committed
getIncompleteOffsetsBelowHighestSucceeded() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
getIncompleteOffsetsBelowHighestSucceeded() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getIterationStartingPoint() - Method in class io.confluent.csid.utils.LoopingResumingIterator
 
getKey() - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
The key of the record being referenced.
getLast(List<T>) - Static method in class io.confluent.csid.utils.JavaUtils
 
getLastFailedAt() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getLastFailureAt() - Method in class io.confluent.parallelconsumer.RecordContext
 
getLastFailureReason() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getLeft() - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
getLinkHtmlToDocSection(String) - Static method in class io.confluent.parallelconsumer.internal.Documentation
 
getLongPollTimeout() - Static method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Note how this relates to BrokerPollSystem.getLongPollTimeout() - if longPollTimeout is high and loading factor is low, there may not be enough messages queued up to satisfy demand.
getLowestRetryTime() - Method in class io.confluent.parallelconsumer.state.ShardManager
 
getLowestRetryTime() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getMagicByte() - Method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
getManagedExecutorService() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Path to Managed executor service for Java EE
getManagedThreadFactory() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Path to Managed thread factory for Java EE
getMaxConcurrency() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Controls the maximum degree of concurrency to occur.
getMaxFactor() - Method in class io.confluent.parallelconsumer.internal.DynamicLoadFactor
Upper safety cap on multiples of target queue size to reach (e.g.
getMaxFailureHistory() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
getMaybeUserFunctionSucceeded() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getMeta() - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
getMyId() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Optional ID of this instance.
getNumberOfAssignedPartitions() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getNumberOfEntriesInPartitionQueues() - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
getNumberOfEntriesInPartitionQueues() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getNumberOfFailedAttempts() - Method in class io.confluent.parallelconsumer.RecordContext
 
getNumberOfFailedAttempts() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getNumberOfWorkQueuedInShardsAwaitingSelection() - Method in class io.confluent.parallelconsumer.state.ShardManager
 
getNumberOfWorkQueuedInShardsAwaitingSelection() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getNumberRecordsOutForProcessing() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getOffset() - Method in class io.confluent.parallelconsumer.state.ConsumerRecordId
 
getOffsetCommitTimeout() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Controls how long to block while waiting for offsets to be committed.
getOffsetHighestSeen() - Method in class io.confluent.parallelconsumer.state.PartitionState
The highest seen offset for a partition.
getOffsetHighestSeen() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getOffsetHighestSequentialSucceeded() - Method in class io.confluent.parallelconsumer.state.PartitionState
Defined for our purpose (as only used in definition of what offset to poll for next), as the offset one below the lowest incomplete offset.
getOffsetHighestSucceeded() - Method in class io.confluent.parallelconsumer.state.PartitionState
Highest offset which has completed successfully ("succeeded").
getOffsetHighestSucceeded() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getOffsets() - Method in class io.confluent.parallelconsumer.PollContext
Map of partitions to offsets.
getOffsets() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getOffsetsFlattened() - Method in class io.confluent.parallelconsumer.PollContext
Get all the offsets for the records in this result set.
getOffsetsFlattened() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getOnlyOne(Map<String, T>) - Static method in class io.confluent.csid.utils.JavaUtils
 
getOptions() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getOptions() - Method in class io.confluent.parallelconsumer.state.ShardManager
 
getOptions() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getOrdering() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
getOut() - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
getPartitionState(TopicPartition) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
getPm() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getPollContext() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getProduceLockAcquisitionTimeout() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Time to allow for acquiring the produce lock.
getProducer() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Supplying a producer is only needed if using the produce flows.
getProducerManager() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getProducerState() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
Tracks the internal transaction state of the Prodocer
getProducerTransactionLock() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
The KafkaProducer isn't actually completely thread safe, at least when using it transactionally.
getProducerWrapper() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
getProducingLock() - Method in class io.confluent.parallelconsumer.PollContextInternal
Used when running in ParallelConsumerOptions.isUsingTransactionCommitMode() then the produce lock will be passed around here.
getQueueTargetLoaded() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getRate() - Method in class io.confluent.parallelconsumer.internal.RateLimiter
 
getRecordContext() - Method in class io.confluent.parallelconsumer.RecordContextInternal
 
getRecordId() - Method in class io.confluent.parallelconsumer.RecordContext
A useful ID class for consumer records.
getRecordMap() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
 
getRecords() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
getRequest() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitResponse
 
getRequestedAtMs() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
getResult() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
getRetryDelayConfig() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getRetryDelayProvider() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
When present, use this to generate a dynamic retry delay, instead of a static one with ParallelConsumerOptions.getDefaultMessageRetryDelay().
getRetryDueAt() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getRight() - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
getRunLengthEncodingIntegers() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
getSendTimeout() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Controls how long to block while waiting for the Producer.send(org.apache.kafka.clients.producer.ProducerRecord<K, V>) to complete for any ProducerRecords returned from the user-function.
getSingleConsumerRecord() - Method in class io.confluent.parallelconsumer.PollContext
Must not be using batching (ParallelConsumerOptions.batchSize).
getSingleConsumerRecord() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getSingleRecord() - Method in class io.confluent.parallelconsumer.PollContext
Must not be using batching (ParallelConsumerOptions.batchSize).
getSingleRecord() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getSingleton() - Static method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getSm() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
getSortedEncodings() - Method in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Ordered set of the different encodings, used to quickly retrieve the most compressed encoding
getStartMs() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
getSucceededAt() - Method in class io.confluent.parallelconsumer.RecordContext
 
getSucceededAt() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getSuccessfulWorkListeners() - Method in class io.confluent.parallelconsumer.state.WorkManager
Useful for testing
getTargetAmountOfRecordsInFlight() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
getTargetOutForProcessing() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getTargetOutForProcessing() - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
 
getThresholdForTimeSpendInQueueWarning() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Configure the amount of delay a record experiences, before a warning is logged.
getTimeBetweenCommits() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Deprecated.
use ParallelConsumerOptions.setCommitInterval(java.time.Duration) instead. This will be deleted in the next major version.
getTimeInFlight() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getTopicName() - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
Note: We use just the topic name here, and not the partition, so that if we were to receive records from the same key from the partitions we're assigned, they will be put into the same queue.
getTopicPartition() - Method in class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
getTopicPartition() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
getTp() - Method in class io.confluent.parallelconsumer.state.ConsumerRecordId
 
getTp() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
getTp() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
getUSED_PAYLOAD_THRESHOLD_MULTIPLIER() - Static method in class io.confluent.parallelconsumer.state.PartitionStateManager
Best efforts attempt to prevent usage of offset payload beyond X% - as encoding size test is currently only done per batch, we need to leave some buffer for the required space to overrun before hitting the hard limit where we have to drop the offset payload entirely.
getWm() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
getWorkContainer() - Method in class io.confluent.parallelconsumer.RecordContext
 
getWorkContainer() - Method in class io.confluent.parallelconsumer.RecordContextInternal
 
getWorkContainers() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
getWorkIfAvailable() - Method in class io.confluent.parallelconsumer.state.WorkManager
Get work with no limit on quantity, useful for testing.
getWorkIfAvailable(int) - Method in class io.confluent.parallelconsumer.state.ShardManager
 
getWorkIfAvailable(int) - Method in class io.confluent.parallelconsumer.state.WorkManager
Depth first work retrieval.
getWorkMailBox() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Collection of work waiting to be
getWorkType() - Method in class io.confluent.parallelconsumer.state.WorkContainer
Simple way to differentiate treatment based on type
groupMetadata() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 

H

handleFutureResult(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.WorkManager
 
hashCode() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
hashCode() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
hashCode() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitResponse
 
hashCode() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
 
hashCode() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
hashCode() - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
hashCode() - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
hashCode() - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
hashCode() - Method in class io.confluent.parallelconsumer.PollContext
 
hashCode() - Method in class io.confluent.parallelconsumer.RecordContext
 
hashCode() - Method in class io.confluent.parallelconsumer.state.ConsumerRecordId
 
hashCode() - Method in class io.confluent.parallelconsumer.state.ShardKey
 
hashCode() - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 
hashCode() - Method in class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
hashCode() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
hasNext() - Method in class io.confluent.csid.utils.LoopingResumingIterator
 
hasPreviouslyFailed() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
hasWorkInCommitQueue() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
hasWorkInCommitQueue() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
hasWorkInCommitQueues() - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
hasWorkInCommitQueues() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
hasWorkInFlight() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
headers() - Method in class io.confluent.parallelconsumer.RecordContext
 
HighestOffsetAndIncompletes(Optional<Long>, Set<Long>) - Constructor for class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 

I

INIT - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
initTransactions() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
INSTANTIATED - Enum constant in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
 
InternalException - Exception in io.confluent.parallelconsumer.internal
Generic Parallel Consumer parent exception.
InternalException() - Constructor for exception io.confluent.parallelconsumer.internal.InternalException
 
InternalRuntimeException - Exception in io.confluent.parallelconsumer.internal
InternalRuntimeException(String, Throwable, Object...) - Constructor for exception io.confluent.parallelconsumer.internal.InternalRuntimeException
 
invoke() - Method in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Highwater mark already encoded in string - OffsetMapCodecManager.makeOffsetMetadataPayload(long, io.confluent.parallelconsumer.state.PartitionState<K, V>) - so encoding BitSet run length may not be needed, or could be swapped
io.confluent.csid.utils - package io.confluent.csid.utils
 
io.confluent.parallelconsumer - package io.confluent.parallelconsumer
 
io.confluent.parallelconsumer.internal - package io.confluent.parallelconsumer.internal
 
io.confluent.parallelconsumer.offsets - package io.confluent.parallelconsumer.offsets
 
io.confluent.parallelconsumer.state - package io.confluent.parallelconsumer.state
 
isAllowEagerProcessingDuringTransactionCommit() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
When using ParallelConsumerOptions.CommitMode.PERIODIC_TRANSACTIONAL_PRODUCER, allows new records to be processed UP UNTIL the result record SENDING (Producer.send(org.apache.kafka.clients.producer.ProducerRecord<K, V>)) step, potentially while a transaction is being committed.
isAllowedMoreRecords(WorkContainer<?, ?>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
isAllowedMoreRecords(TopicPartition) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Check we have capacity in offset storage to process more messages
isAsyncFutureWork(List<?>) - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
System dependent way for the core engine to know if an external scheduler needs to be relied on for completion, as opposed to the internal threading system in the core module.
isAvailableToTakeAsWork() - Method in class io.confluent.parallelconsumer.state.WorkContainer
Checks the work is not already in flight, it's retry delay has passed and that it's not already been succeeded.
isBlank(String) - Static method in class io.confluent.csid.utils.StringUtils
 
isBlocked() - Method in class io.confluent.parallelconsumer.state.PartitionState
Convenience method for readability
isBlocked(TopicPartition) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Checks if partition is blocked with back pressure.
isClosedOrFailed() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
isConfiguredForTransactions() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
isDelayPassed() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
isDirty() - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
isDirty() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
isEmpty() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
isEmpty(Optional<?>) - Static method in class io.confluent.csid.utils.BackportUtils
 
isGreaterThan(Duration, Duration) - Static method in class io.confluent.csid.utils.JavaUtils
 
isInFlight() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
isMaxReached() - Method in class io.confluent.parallelconsumer.internal.DynamicLoadFactor
 
isMockProducer() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
isNoRecordsOutForProcessing() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
isNotInFlight() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
isPartitionRemovedOrNeverAssigned(ConsumerRecord<?, ?>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
isPausedForThrottling() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
While paused is an externally controlled state that temporarily stops polling and work registration, the paused flag is used internally to pause subscriptions if polling needs to be throttled.
isProducerSupplied() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
isRecordPreviouslyCompleted(ConsumerRecord<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
isRecordPreviouslyCompleted(ConsumerRecord<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
isRecordPreviouslyCompleted(ConsumerRecord<K, V>) - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
isRecordsAwaitingProcessing() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
isRecordsAwaitingToBeCommitted() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
isRemoved() - Method in class io.confluent.parallelconsumer.state.PartitionState
Has this partition been removed? No.
isRemoved() - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
isSufficientlyLoaded() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
isSync() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter
 
isTimeToCommitNow() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
isTransactionCommittingInProgress() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
isTransactionCompleting() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
isTransactionOpen() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
According to our state tracking, does the Producer have an open transaction
isTransactionReady() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
isUserFunctionComplete() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
isUserFunctionSucceeded() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
isUsingBatching() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
isUsingTransactionalProducer() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
isUsingTransactionCommitMode() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
isWarmUpPeriodOver() - Method in class io.confluent.parallelconsumer.internal.DynamicLoadFactor
Is the warm-up period over?
isWorkInFlightMeetingTarget() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
iterator() - Method in class io.confluent.csid.utils.LoopingResumingIterator
 
iterator() - Method in class io.confluent.csid.utils.Range
 
iterator() - Method in class io.confluent.parallelconsumer.PollContext
 
iterator() - Method in class io.confluent.parallelconsumer.PollContextInternal
 

J

Java8StreamUtils - Class in io.confluent.csid.utils
 
JavaUtils - Class in io.confluent.csid.utils
 
JStreamParallelEoSStreamProcessor<K,V> - Class in io.confluent.parallelconsumer
 
JStreamParallelEoSStreamProcessor(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.JStreamParallelEoSStreamProcessor
 
JStreamParallelStreamProcessor<K,V> - Interface in io.confluent.parallelconsumer
 

K

KAFKA_DEFAULT_AUTO_COMMIT_INTERVAL_MS - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions
Kafka's default auto commit interval - which is 5000ms.
KAFKA_OFFSET_ABSENCE - Static variable in class io.confluent.parallelconsumer.state.PartitionState
Symbolic value for a parameter which is initialised as having an offset absent (instead of using Optional or null)
KafkaUtils - Class in io.confluent.csid.utils
Simple identifier tuple for Topic Partitions
KafkaUtils() - Constructor for class io.confluent.csid.utils.KafkaUtils
 
key() - Method in class io.confluent.parallelconsumer.PollContext
For backwards compatibility with ConsumerRecord.key().
key() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
key() - Method in class io.confluent.parallelconsumer.RecordContext
 
KEY - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.ProcessingOrder
Process messages in key order.
KeyOrderedKey(ConsumerRecord<?, ?>) - Constructor for class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 
KeyOrderedKey(TopicPartition, Object) - Constructor for class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 

L

LARGE_INPUT_MAP_SIZE_THRESHOLD - Static variable in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Size threshold in bytes after which compressing the encodings will be compared, as it seems to be typically worth the extra compression step when beyond this size in the source array.
leaderEpoch() - Method in class io.confluent.parallelconsumer.RecordContext
 
list() - Method in class io.confluent.csid.utils.Range
 
loadPartitionStateForAssignment(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
Load all the previously completed offsets that were not committed
LoopingResumingIterator<KEY,VALUE> - Class in io.confluent.csid.utils
Loop implementations that will resume from a given key.
LoopingResumingIterator(Map<KEY, VALUE>) - Constructor for class io.confluent.csid.utils.LoopingResumingIterator
 
LoopingResumingIterator(Optional<KEY>, Map<KEY, VALUE>) - Constructor for class io.confluent.csid.utils.LoopingResumingIterator
Will resume from the startingKey, if it's present

M

magicByte - Variable in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
makeOffsetMetadataPayload(long, PartitionState<K, V>) - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
 
managedExecutorService - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
managedExecutorService(String) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Path to Managed executor service for Java EE
managedThreadFactory - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
managedThreadFactory(String) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Path to Managed thread factory for Java EE
max(Duration, Duration) - Static method in class io.confluent.csid.utils.JavaUtils
 
MAX_LENGTH_ENCODABLE - Static variable in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
maxConcurrency - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
maxConcurrency(int) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Controls the maximum degree of concurrency to occur.
maxFailureHistory - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
maxFailureHistory(int) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
 
maybeStepUp() - Method in class io.confluent.parallelconsumer.internal.DynamicLoadFactor
Try to increase the loading factor
MDC_INSTANCE_ID - Static variable in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
METADATA_DATA_SIZE_RESOURCE_LOCK - Static variable in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
Used to prevent tests running in parallel that depends on setting static state in this class.
metrics() - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
msg(String, Object...) - Static method in class io.confluent.csid.utils.StringUtils
 
msg(String, Object...) - Static method in exception io.confluent.parallelconsumer.internal.InternalRuntimeException
 
MSG - Static variable in class io.confluent.parallelconsumer.internal.UserFunctions
 

N

next() - Method in class io.confluent.csid.utils.LoopingResumingIterator
 
NO_OP - Static variable in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
NoEncodingPossibleException - Exception in io.confluent.parallelconsumer.offsets
 
NoEncodingPossibleException(String) - Constructor for exception io.confluent.parallelconsumer.offsets.NoEncodingPossibleException
 
notifySomethingToDo() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Early notify of work arrived.

O

of() - Static method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
of(long) - Static method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
of(long, Set<Long>) - Static method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
of(WorkContainer<?, ?>, ParallelConsumerOptions.ProcessingOrder) - Static method in class io.confluent.parallelconsumer.state.ShardKey
 
of(ConsumerRecord<?, ?>, ParallelConsumerOptions.ProcessingOrder) - Static method in class io.confluent.parallelconsumer.state.ShardKey
 
offset() - Method in class io.confluent.parallelconsumer.PollContext
For backwards compatibility with ConsumerRecord.offset().
offset() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
offset() - Method in class io.confluent.parallelconsumer.RecordContext
 
offset() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
OffsetBitSet - Class in io.confluent.parallelconsumer.offsets
Deserialisation tools for BitSetEncoder.
OffsetBitSet() - Constructor for class io.confluent.parallelconsumer.offsets.OffsetBitSet
 
OffsetCommitter - Interface in io.confluent.parallelconsumer.internal
Contract for committing offsets.
offsetCommitTimeout - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
offsetCommitTimeout(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Controls how long to block while waiting for offsets to be committed.
OffsetDecodingError - Exception in io.confluent.parallelconsumer.offsets
 
OffsetDecodingError(String, IllegalArgumentException) - Constructor for exception io.confluent.parallelconsumer.offsets.OffsetDecodingError
 
OffsetEncoder - Class in io.confluent.parallelconsumer.offsets
Base OffsetEncoder
OffsetEncoder(OffsetSimultaneousEncoder) - Constructor for class io.confluent.parallelconsumer.offsets.OffsetEncoder
 
OffsetEncoding - Enum Class in io.confluent.parallelconsumer.offsets
 
OffsetEncoding.Version - Enum Class in io.confluent.parallelconsumer.offsets
 
OffsetMapCodecManager<K,V> - Class in io.confluent.parallelconsumer.offsets
Uses multiple encodings to compare, when decided, can refactor other options out for analysis only - OffsetMapCodecManager.encodeOffsetsCompressed(long, io.confluent.parallelconsumer.state.PartitionState<K, V>)
OffsetMapCodecManager(Consumer<K, V>) - Constructor for class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager
 
OffsetMapCodecManager.HighestOffsetAndIncompletes - Class in io.confluent.parallelconsumer.offsets
Decoding result for encoded offsets
OffsetRunLength - Class in io.confluent.parallelconsumer.offsets
 
OffsetSimpleSerialisation - Class in io.confluent.parallelconsumer.offsets
 
OffsetSimultaneousEncoder - Class in io.confluent.parallelconsumer.offsets
Encode with multiple strategies at the same time.
OffsetSimultaneousEncoder(long, long, Set<Long>) - Constructor for class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
 
ofKey(ConsumerRecord<?, ?>) - Static method in class io.confluent.parallelconsumer.state.ShardKey
 
ofTopicPartition(ConsumerRecord<?, ?>) - Static method in class io.confluent.parallelconsumer.state.ShardKey
 
onCommitRequested() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
onFailure(WorkContainer<?, ?>) - Method in class io.confluent.parallelconsumer.state.ShardManager
Idempotent - work may have not been removed, either way it's put back
onFailure(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
onFailure(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
onFailureResult(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.WorkManager
 
onOffsetCommitSuccess(Map<TopicPartition, OffsetAndMetadata>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Truncate our tracked offsets as a commit was successful, so the low water mark rises, and we dont' need to track as much anymore.
onOffsetCommitSuccess(Map<TopicPartition, OffsetAndMetadata>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Can run from controller or poller thread, depending on which is responsible for committing
onOffsetCommitSuccess(OffsetAndMetadata) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
onPartitionsAssigned(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Delegate to WorkManager
onPartitionsAssigned(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Load offset map for assigned assignedPartitions
onPartitionsAssigned(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Load offset map for assigned partitions
onPartitionsLost(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Cannot commit any offsets for partitions that have been `lost` (as opposed to revoked).
onPartitionsLost(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Clear offset map for lost partitions
onPartitionsLost(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Clear offset map for lost partitions
onPartitionsRemoved(ShardManager<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Commit our offsets
onPartitionsRevoked(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
Clear offset map for revoked partitions
onPartitionsRevoked(Collection<TopicPartition>) - Method in class io.confluent.parallelconsumer.state.WorkManager
Clear offset map for revoked partitions
onPostAddToMailBox(PollContextInternal<K, V>, Optional<ProducerManager<K, V>>) - Method in class io.confluent.parallelconsumer.state.WorkContainer
Only unlock our producing lock, when we've had the WorkContainer state safely returned to the controllers inbound queue, so we know it'll be included properly before the next commit as a succeeded offset.
onQueueingForExecution() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
onSuccess(WorkContainer<?, ?>) - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
onSuccess(WorkContainer<?, ?>) - Method in class io.confluent.parallelconsumer.state.ShardManager
 
onSuccess(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionState
 
onSuccess(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.PartitionStateManager
 
onSuccess(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.RemovedPartitionState
 
onSuccessResult(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.state.WorkManager
 
onUserFunctionFailure(Throwable) - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
onUserFunctionSuccess() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
onUserFunctionSuccess(WorkContainer<K, V>, List<?>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
onUserFunctionSuccess(WorkContainer<K, V>, List<?>) - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
With Vertx and Reactor, a function hasn't succeeded until the inner vertx function has also succeeded logging
options - Variable in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
options() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
optionsInstance - Variable in class io.confluent.parallelconsumer.internal.PCModule
 
ordering - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
ordering(ParallelConsumerOptions.ProcessingOrder) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder

P

packSmallest() - Method in class io.confluent.parallelconsumer.offsets.OffsetSimultaneousEncoder
Select the smallest encoding, and pack it.
pairOf(LL, RR) - Static method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
ParallelConsumer<K,V> - Interface in io.confluent.parallelconsumer
Asynchronous / concurrent message consumer for Kafka.
ParallelConsumer.Tuple<L,R> - Class in io.confluent.parallelconsumer
A simple tuple structure.
ParallelConsumerException - Exception in io.confluent.parallelconsumer
Generic Parallel Consumer RuntimeException parent.
ParallelConsumerException() - Constructor for exception io.confluent.parallelconsumer.ParallelConsumerException
 
ParallelConsumerOptions<K,V> - Class in io.confluent.parallelconsumer
The options for the AbstractParallelEoSStreamProcessor system.
ParallelConsumerOptions.CommitMode - Enum Class in io.confluent.parallelconsumer
The type of commit to be made, with either a transactions configured Producer where messages produced are committed back to the Broker along with the offsets they originated from, or with the faster simpler Consumer offset system either synchronously or asynchronously
ParallelConsumerOptions.Fields - Class in io.confluent.parallelconsumer
 
ParallelConsumerOptions.ParallelConsumerOptionsBuilder<K,V> - Class in io.confluent.parallelconsumer
 
ParallelConsumerOptions.ProcessingOrder - Enum Class in io.confluent.parallelconsumer
The ordering guarantee to use.
parallelEoSStreamProcessor - Variable in class io.confluent.parallelconsumer.internal.PCModule
 
ParallelEoSStreamProcessor<K,V> - Class in io.confluent.parallelconsumer
 
ParallelEoSStreamProcessor(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
ParallelEoSStreamProcessor(ParallelConsumerOptions<K, V>, PCModule<K, V>) - Constructor for class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
Construct the AsyncConsumer by wrapping this passed in consumer and producer, which can be configured any which way as per normal.
ParallelStreamProcessor<K,V> - Interface in io.confluent.parallelconsumer
Parallel message consumer which also can optionally produce 0 or many ProducerRecord results to be published back to Kafka.
ParallelStreamProcessor.ConsumeProduceResult<K,V,KK,VV> - Class in io.confluent.parallelconsumer
A simple triple structure to capture the set of coinciding data.
partition() - Method in class io.confluent.parallelconsumer.RecordContext
 
PARTITION - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.ProcessingOrder
Process messages within a partition in order, but process multiple partitions in parallel.
partitions() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
Get the partitions which have records contained in this record set.
partitionsFor(String) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
PartitionState<K,V> - Class in io.confluent.parallelconsumer.state
 
PartitionState(TopicPartition, OffsetMapCodecManager.HighestOffsetAndIncompletes) - Constructor for class io.confluent.parallelconsumer.state.PartitionState
 
PartitionStateManager<K,V> - Class in io.confluent.parallelconsumer.state
In charge of managing PartitionStates.
PartitionStateManager(PCModule<K, V>, ShardManager<K, V>) - Constructor for class io.confluent.parallelconsumer.state.PartitionStateManager
 
pause(Set<TopicPartition>) - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
paused - Enum constant in enum class io.confluent.parallelconsumer.internal.State
When paused, the system will stop submitting work to the processing pool.
paused() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
pauseIfRunning() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
pauseIfRunning() - Method in interface io.confluent.parallelconsumer.ParallelConsumer
Pause this consumer (i.e.
pausePollingAndWorkRegistrationIfRunning() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Pause polling from the underlying Kafka Broker.
pc() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
PCModule<K,V> - Class in io.confluent.parallelconsumer.internal
Minimum dependency injection system, modled on how Dagger works.
PCModule(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.PCModule
 
performIfNotLimited(Runnable) - Method in class io.confluent.parallelconsumer.internal.RateLimiter
 
PERIODIC_CONSUMER_ASYNCHRONOUS - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.CommitMode
Periodically commits offsets asynchronously.
PERIODIC_CONSUMER_SYNC - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.CommitMode
Periodically synchronous commits with the Consumer.
PERIODIC_TRANSACTIONAL_PRODUCER - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.CommitMode
Periodically commits through the Producer using transactions.
poll(Consumer<PollContext<K, V>>) - Method in class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
poll(Consumer<PollContext<K, V>>) - Method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
Register a function to be applied in parallel to each received message
pollAndProduce(Function<PollContext<K, V>, ProducerRecord<K, V>>) - Method in class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
pollAndProduce(Function<PollContext<K, V>, ProducerRecord<K, V>>) - Method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
Register a function to be applied in parallel to each received message, which in turn returns a ProducerRecord to be sent back to the broker.
pollAndProduce(Function<PollContext<K, V>, ProducerRecord<K, V>>, Consumer<ParallelStreamProcessor.ConsumeProduceResult<K, V, K, V>>) - Method in class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
pollAndProduce(Function<PollContext<K, V>, ProducerRecord<K, V>>, Consumer<ParallelStreamProcessor.ConsumeProduceResult<K, V, K, V>>) - Method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
Register a function to be applied in parallel to each received message, which in turn returns a ProducerRecord to be sent back to the broker.
pollAndProduceMany(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>) - Method in class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
pollAndProduceMany(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>) - Method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
Register a function to be applied in parallel to each received message, which in turn returns one or many ProducerRecords to be sent back to the broker.
pollAndProduceMany(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>, Consumer<ParallelStreamProcessor.ConsumeProduceResult<K, V, K, V>>) - Method in class io.confluent.parallelconsumer.ParallelEoSStreamProcessor
 
pollAndProduceMany(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>, Consumer<ParallelStreamProcessor.ConsumeProduceResult<K, V, K, V>>) - Method in interface io.confluent.parallelconsumer.ParallelStreamProcessor
Register a function to be applied in parallel to each received message, which in turn returns one or more ProducerRecords to be sent back to the broker.
PollContext<K,V> - Class in io.confluent.parallelconsumer
Context object used to pass messages to process to users processing functions.
PollContext() - Constructor for class io.confluent.parallelconsumer.PollContext
 
PollContextInternal<K,V> - Class in io.confluent.parallelconsumer
Internal only view on the PollContext.
PollContextInternal(List<WorkContainer<K, V>>) - Constructor for class io.confluent.parallelconsumer.PollContextInternal
 
pollProduceAndStream(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>) - Method in class io.confluent.parallelconsumer.JStreamParallelEoSStreamProcessor
 
pollProduceAndStream(Function<PollContext<K, V>, List<ProducerRecord<K, V>>>) - Method in interface io.confluent.parallelconsumer.JStreamParallelStreamProcessor
Like AbstractParallelEoSStreamProcessor#pollAndProduceMany but instead of callbacks, streams the results instead, after the produce result is ack'd by Kafka.
postCommit() - Method in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
postCommit() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter
 
postCommit() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
Only release lock when commit successful
preAcquireOffsetsToCommit() - Method in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
preAcquireOffsetsToCommit() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
First lock, so no other records can be sent.
ProcessingShard<K,V> - Class in io.confluent.parallelconsumer.state
Models the queue of work to be processed, based on the ParallelConsumerOptions.ProcessingOrder modes.
ProcessingShard(ShardKey, ParallelConsumerOptions<?, ?>, PartitionStateManager<K, V>) - Constructor for class io.confluent.parallelconsumer.state.ProcessingShard
 
processWorkCompleteMailBox(Duration) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Check the work queue for work to be done, potentially blocking.
produceLockAcquisitionTimeout - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
produceLockAcquisitionTimeout(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Time to allow for acquiring the produce lock.
produceMessages(List<ProducerRecord<K, V>>) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
Produce a message back to the broker.
producer - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
producer() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
producer(Producer<K, V>) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Supplying a producer is only needed if using the produce flows.
producerManager() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
ProducerManager<K,V> - Class in io.confluent.parallelconsumer.internal
Sub system for interacting with the Producer and managing transactions (and thus offset committing through the Producer).
ProducerManager(ProducerWrapper<K, V>, ConsumerManager<K, V>, WorkManager<K, V>, ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.ProducerManager
 
ProducerManager.ProducingLock - Class in io.confluent.parallelconsumer.internal
Readability wrapper on the ReentrantReadWriteLock.ReadLocks of our ProducerManager.producerTransactionLock.
producerWrap() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
producerWrapper - Variable in class io.confluent.parallelconsumer.internal.ProducerManager
 
ProducerWrapper<K,V> - Class in io.confluent.parallelconsumer.internal
Our extension of the standard Producer to mostly add some introspection functions and state tracking.
ProducerWrapper(ParallelConsumerOptions<K, V>, boolean, Producer<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.ProducerWrapper
 
ProducerWrapper(ParallelConsumerOptions<K, V>) - Constructor for class io.confluent.parallelconsumer.internal.ProducerWrapper
 
ProducerWrapper.ProducerState - Enum Class in io.confluent.parallelconsumer.internal
Used to track Producer's transaction state, as it' isn't otherwise exposed.
producingLock - Variable in class io.confluent.parallelconsumer.PollContextInternal
Used when running in ParallelConsumerOptions.isUsingTransactionCommitMode() then the produce lock will be passed around here.
ProducingLock(PollContextInternal<K, V>, ReentrantReadWriteLock.ReadLock) - Constructor for class io.confluent.parallelconsumer.internal.ProducerManager.ProducingLock
 

R

range(long) - Static method in class io.confluent.csid.utils.Range
Exclusive of max
Range - Class in io.confluent.csid.utils
https://stackoverflow.com/a/16570509/105741
Range(long) - Constructor for class io.confluent.csid.utils.Range
 
RateLimiter - Class in io.confluent.parallelconsumer.internal
 
RateLimiter() - Constructor for class io.confluent.parallelconsumer.internal.RateLimiter
 
RateLimiter(int) - Constructor for class io.confluent.parallelconsumer.internal.RateLimiter
 
readDataArrayForDebug() - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
Copies array out of the ByteBuffer
readFully(InputStream) - Static method in class io.confluent.csid.utils.BackportUtils
 
readFully(InputStream, int, boolean) - Static method in class io.confluent.csid.utils.BackportUtils
Used in Java 8 environments (Java 9 has read all bytes)
RecordContext<K,V> - Class in io.confluent.parallelconsumer
Context information for the wrapped ConsumerRecord.
RecordContext(WorkContainer<K, V>) - Constructor for class io.confluent.parallelconsumer.RecordContext
 
RecordContext(WorkContainer<K, V>, ConsumerRecord<K, V>) - Constructor for class io.confluent.parallelconsumer.RecordContext
 
RecordContext.RecordContextBuilder<K,V> - Class in io.confluent.parallelconsumer
 
RecordContextInternal<K,V> - Class in io.confluent.parallelconsumer
Internal only view of the RecordContext class.
RecordContextInternal(WorkContainer<K, V>) - Constructor for class io.confluent.parallelconsumer.RecordContextInternal
 
records - Variable in class io.confluent.parallelconsumer.PollContext
 
records(TopicPartition) - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
Get just the records for the given partition
RecordsAndEpoch(Long, List<ConsumerRecord<K, V>>) - Constructor for class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
registerWork(EpochAndRecordsMap<K, V>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
registerWork(EpochAndRecordsMap<K, V>) - Method in class io.confluent.parallelconsumer.state.WorkManager
 
releaseProduceLock(ProducerManager.ProducingLock) - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
remap(Map<K, V1>, Function<? super V1, ? extends V2>) - Static method in class io.confluent.csid.utils.JavaUtils
A shortcut for changing only the values of a Map.
remove(long) - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
RemovedPartitionState<K,V> - Class in io.confluent.parallelconsumer.state
No op version of PartitionState used for when partition assignments are removed, to avoid managing null references or Optionals.
RemovedPartitionState() - Constructor for class io.confluent.parallelconsumer.state.RemovedPartitionState
 
requestCommitAsap() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Request a commit as soon as possible (ASAP), overriding other constraints.
result(RESULT) - Method in class io.confluent.csid.utils.TimeUtils.TimeResult.TimeResultBuilder
 
resume(Set<TopicPartition>) - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
resumeIfPaused() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
resumeIfPaused() - Method in interface io.confluent.parallelconsumer.ParallelConsumer
Resume this consumer (i.e.
resumePollingAndWorkRegistrationIfPaused() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Resume polling from the underlying Kafka Broker.
retrieveOffsetsAndCommit() - Method in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
Get offsets from WorkManager that are ready to commit
retrieveOffsetsAndCommit() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Optionally blocks.
retrieveOffsetsAndCommit() - Method in interface io.confluent.parallelconsumer.internal.OffsetCommitter
 
retryDelayProvider - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
retryDelayProvider(Function<RecordContext<K, V>, Duration>) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
When present, use this to generate a dynamic retry delay, instead of a static one with ParallelConsumerOptions.getDefaultMessageRetryDelay().
RunLength - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
RunLengthCompressed - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
RunLengthEncoder - Class in io.confluent.parallelconsumer.offsets
RunLength encoder that leverages the nature of this system.
RunLengthEncoder(OffsetSimultaneousEncoder, OffsetEncoding.Version) - Constructor for class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
RunlengthV1EncodingNotSupported - Exception in io.confluent.parallelconsumer.offsets
 
RunlengthV1EncodingNotSupported(String) - Constructor for exception io.confluent.parallelconsumer.offsets.RunlengthV1EncodingNotSupported
 
RunLengthV2 - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
switch from encoding run lengths as Shorts to Integers
RunLengthV2Compressed - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
running - Enum constant in enum class io.confluent.parallelconsumer.internal.State
 
runUserFunction(Function<PollContextInternal<K, V>, List<R>>, Consumer<R>, List<WorkContainer<K, V>>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Run the supplied function.

S

send(ProducerRecord<K, V>) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
send(ProducerRecord<K, V>, Callback) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class io.confluent.parallelconsumer.internal.ProducerWrapper
 
sendTimeout - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
sendTimeout(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Controls how long to block while waiting for the Producer.send(org.apache.kafka.clients.producer.ProducerRecord<K, V>) to complete for any ProducerRecords returned from the user-function.
serialise() - Method in class io.confluent.parallelconsumer.offsets.BitSetEncoder
 
serialise() - Method in class io.confluent.parallelconsumer.offsets.ByteBufferEncoder
 
serialise() - Method in class io.confluent.parallelconsumer.offsets.RunLengthEncoder
 
serializedKeySize() - Method in class io.confluent.parallelconsumer.RecordContext
 
serializedValueSize() - Method in class io.confluent.parallelconsumer.RecordContext
 
setCommitInterval(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
Deprecated.
setFuture(Future<List<?>>) - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
setLongPollTimeout(Duration) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
setLongPollTimeout(Duration) - Static method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Note how this relates to BrokerPollSystem.getLongPollTimeout() - if longPollTimeout is high and loading factor is low, there may not be enough messages queued up to satisfy demand.
setMyId(Optional<String>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Optional ID of this instance.
setParallelEoSStreamProcessor(AbstractParallelEoSStreamProcessor<K, V>) - Method in class io.confluent.parallelconsumer.internal.PCModule
 
setProducingLock(Optional<ProducerManager.ProducingLock>) - Method in class io.confluent.parallelconsumer.PollContextInternal
Used when running in ParallelConsumerOptions.isUsingTransactionCommitMode() then the produce lock will be passed around here.
setState(State) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
The run state of the controller.
setTimeBetweenCommits(Duration) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Deprecated.
use ParallelConsumerOptions.ParallelConsumerOptionsBuilder.commitInterval(java.time.Duration)} instead. This will be deleted in the next major version.
setupStreamFromDeque(ConcurrentLinkedDeque<T>) - Static method in class io.confluent.csid.utils.Java8StreamUtils
 
setupWorkerPool(int) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
setupWorkerPool(int) - Method in class io.confluent.parallelconsumer.internal.ExternalEngine
The vert.x module doesn't use any thread pool for dispatching work, as the work is all done by the vert.x engine.
setUSED_PAYLOAD_THRESHOLD_MULTIPLIER(double) - Static method in class io.confluent.parallelconsumer.state.PartitionStateManager
Best efforts attempt to prevent usage of offset payload beyond X% - as encoding size test is currently only done per batch, we need to leave some buffer for the required space to overrun before hitting the hard limit where we have to drop the offset payload entirely.
setWorkManager(WorkManager<K, V>) - Method in class io.confluent.parallelconsumer.internal.PCModule
 
setWorkType(String) - Method in class io.confluent.parallelconsumer.state.WorkContainer
Simple way to differentiate treatment based on type
ShardKey - Class in io.confluent.parallelconsumer.state
Simple value class for processing ShardKeys to make the various key systems type safe and extendable.
ShardKey() - Constructor for class io.confluent.parallelconsumer.state.ShardKey
 
ShardKey.KeyOrderedKey - Class in io.confluent.parallelconsumer.state
 
ShardKey.TopicPartitionKey - Class in io.confluent.parallelconsumer.state
 
ShardManager<K,V> - Class in io.confluent.parallelconsumer.state
Shards are local queues of work to be processed.
ShardManager(ParallelConsumerOptions, WorkManager<K, V>) - Constructor for class io.confluent.parallelconsumer.state.ShardManager
 
shouldThrottle() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
size() - Method in class io.confluent.parallelconsumer.PollContext
 
size() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
SIZE_COMPARATOR - Static variable in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
 
spliterator() - Method in class io.confluent.parallelconsumer.PollContext
 
spliterator() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
start(String) - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
 
startMs(long) - Method in class io.confluent.csid.utils.TimeUtils.TimeResult.TimeResultBuilder
 
State - Enum Class in io.confluent.parallelconsumer.internal
The run state of the controller.
stream() - Method in class io.confluent.parallelconsumer.PollContext
 
stream() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
streamConsumerRecords() - Method in class io.confluent.parallelconsumer.PollContext
 
streamConsumerRecords() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
streamInternal() - Method in class io.confluent.parallelconsumer.PollContext
 
streamInternal() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
streamWorkContainers() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
StringUtils - Class in io.confluent.csid.utils
 
StringUtils() - Constructor for class io.confluent.csid.utils.StringUtils
 
submitWorkToPool(Function<PollContextInternal<K, V>, List<R>>, Consumer<R>, List<WorkContainer<K, V>>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Submit a piece of work to the processing pool.
subscribe(Collection<String>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
subscribe(Collection<String>) - Method in interface io.confluent.parallelconsumer.ParallelConsumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface io.confluent.parallelconsumer.ParallelConsumer
 
subscribe(Pattern) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
subscribe(Pattern) - Method in interface io.confluent.parallelconsumer.ParallelConsumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in interface io.confluent.parallelconsumer.ParallelConsumer
 
supervise() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
 
supervisorLoop(Function<PollContextInternal<K, V>, List<R>>, Consumer<R>) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Kicks off the control loop in the executor, with supervision and returns.

T

thresholdForTimeSpendInQueueWarning - Static variable in class io.confluent.parallelconsumer.ParallelConsumerOptions.Fields
 
thresholdForTimeSpendInQueueWarning(Duration) - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
Configure the amount of delay a record experiences, before a warning is logged.
time(Callable<RESULT>) - Static method in class io.confluent.csid.utils.TimeUtils
 
timestamp() - Method in class io.confluent.parallelconsumer.RecordContext
 
timestampType() - Method in class io.confluent.parallelconsumer.RecordContext
 
TimeUtils - Class in io.confluent.csid.utils
 
TimeUtils.TimeResult<RESULT> - Class in io.confluent.csid.utils
 
TimeUtils.TimeResult.TimeResultBuilder<RESULT> - Class in io.confluent.csid.utils
 
timeWithMeta(Callable<? extends RESULT>) - Static method in class io.confluent.csid.utils.TimeUtils
 
toBuilder() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
toBuilder() - Method in class io.confluent.parallelconsumer.RecordContext
 
topic() - Method in class io.confluent.parallelconsumer.RecordContext
 
TopicPartitionKey(TopicPartition) - Constructor for class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
toSeconds(Duration) - Static method in class io.confluent.csid.utils.BackportUtils
 
toStream() - Method in class io.confluent.csid.utils.Range
 
toString() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult.TimeResultBuilder
 
toString() - Method in class io.confluent.csid.utils.TimeUtils.TimeResult
 
toString() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitRequest
 
toString() - Method in class io.confluent.parallelconsumer.internal.ConsumerOffsetCommitter.CommitResponse
 
toString() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap.RecordsAndEpoch
 
toString() - Method in class io.confluent.parallelconsumer.internal.EpochAndRecordsMap
 
toString() - Method in class io.confluent.parallelconsumer.internal.ProducerManager
 
toString() - Method in class io.confluent.parallelconsumer.offsets.EncodedOffsetPair
Used for printing out the comparative map of each encoder
toString() - Method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 
toString() - Method in class io.confluent.parallelconsumer.offsets.OffsetMapCodecManager.HighestOffsetAndIncompletes
 
toString() - Method in class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 
toString() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions.ParallelConsumerOptionsBuilder
 
toString() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
toString() - Method in class io.confluent.parallelconsumer.ParallelStreamProcessor.ConsumeProduceResult
 
toString() - Method in class io.confluent.parallelconsumer.PollContext
 
toString() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
toString() - Method in class io.confluent.parallelconsumer.RecordContext.RecordContextBuilder
 
toString() - Method in class io.confluent.parallelconsumer.RecordContext
 
toString() - Method in class io.confluent.parallelconsumer.RecordContextInternal
 
toString() - Method in class io.confluent.parallelconsumer.state.ConsumerRecordId
 
toString() - Method in class io.confluent.parallelconsumer.state.PartitionState
 
toString() - Method in class io.confluent.parallelconsumer.state.ShardKey.KeyOrderedKey
 
toString() - Method in class io.confluent.parallelconsumer.state.ShardKey.TopicPartitionKey
 
toString() - Method in class io.confluent.parallelconsumer.state.ShardKey
 
toString() - Method in class io.confluent.parallelconsumer.state.WorkContainer
 
toTopicPartition(ConsumerRecord<?, ?>) - Static method in class io.confluent.csid.utils.KafkaUtils
 
Tuple(L, R) - Constructor for class io.confluent.parallelconsumer.ParallelConsumer.Tuple
 

U

unlock() - Method in class io.confluent.parallelconsumer.internal.ProducerManager.ProducingLock
Unlocks the produce lock
UNORDERED - Enum constant in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.ProcessingOrder
No ordering is guaranteed, not even partition order.
unused - Enum constant in enum class io.confluent.parallelconsumer.internal.State
 
updateMetadataCache() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
 
USED_PAYLOAD_THRESHOLD_MULTIPLIER_DEFAULT - Static variable in class io.confluent.parallelconsumer.state.PartitionStateManager
 
UserFunctions - Class in io.confluent.parallelconsumer.internal
Single entry point for wrapping the actual execution of user functions

V

v1 - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding.Version
 
v2 - Enum constant in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding.Version
 
validate() - Method in class io.confluent.parallelconsumer.ParallelConsumerOptions
 
value() - Method in class io.confluent.parallelconsumer.PollContext
For backwards compatibility with ConsumerRecord.value().
value() - Method in class io.confluent.parallelconsumer.PollContextInternal
 
value() - Method in class io.confluent.parallelconsumer.RecordContext
 
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.internal.DrainingCloseable.DrainingMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.internal.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding.Version
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.CommitMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.ProcessingOrder
Returns the enum constant of this class with the specified name.
values() - Static method in enum class io.confluent.parallelconsumer.internal.DrainingCloseable.DrainingMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.internal.ProducerWrapper.ProducerState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.internal.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding.Version
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.CommitMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.confluent.parallelconsumer.ParallelConsumerOptions.ProcessingOrder
Returns an array containing the constants of this enum class, in the order they are declared.
version - Variable in enum class io.confluent.parallelconsumer.offsets.OffsetEncoding
 

W

waitForProcessedNotCommitted(Duration) - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
Deprecated.
no longer used, will be removed in next version
wakeup() - Method in class io.confluent.parallelconsumer.internal.ConsumerManager
Wakes up the consumer, but only if it's polling.
wakeupIfPaused() - Method in class io.confluent.parallelconsumer.internal.BrokerPollSystem
Wakeup if colling the broker
wm - Variable in class io.confluent.parallelconsumer.internal.AbstractOffsetCommitter
 
wm - Variable in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
workContainer - Variable in class io.confluent.parallelconsumer.RecordContext
 
workContainer(WorkContainer<K, V>) - Method in class io.confluent.parallelconsumer.RecordContext.RecordContextBuilder
 
WorkContainer<K,V> - Class in io.confluent.parallelconsumer.state
Model object for metadata around processing state of ConsumerRecords.
WorkContainer(long, ConsumerRecord<K, V>, PCModule<K, V>, String) - Constructor for class io.confluent.parallelconsumer.state.WorkContainer
 
WorkContainer(long, ConsumerRecord<K, V>, PCModule<K, V>) - Constructor for class io.confluent.parallelconsumer.state.WorkContainer
 
workerThreadPool - Variable in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
The pool which is used for running the users' supplied function
workIsWaitingToBeProcessed() - Method in class io.confluent.parallelconsumer.state.ProcessingShard
 
workIsWaitingToBeProcessed() - Method in class io.confluent.parallelconsumer.state.ShardManager
 
workIsWaitingToBeProcessed() - Method in class io.confluent.parallelconsumer.state.WorkManager
 
workManager() - Method in class io.confluent.parallelconsumer.internal.PCModule
 
WorkManager<K,V> - Class in io.confluent.parallelconsumer.state
Sharded, prioritised, offset managed, order controlled, delayed work queue.
WorkManager(PCModule<K, V>) - Constructor for class io.confluent.parallelconsumer.state.WorkManager
Use a private DynamicLoadFactor, useful for testing.
WorkManager(PCModule<K, V>, DynamicLoadFactor) - Constructor for class io.confluent.parallelconsumer.state.WorkManager
 
workRemaining() - Method in class io.confluent.parallelconsumer.internal.AbstractParallelEoSStreamProcessor
 
workRemaining() - Method in interface io.confluent.parallelconsumer.internal.DrainingCloseable
Of the records consumed from the broker, how many do we have remaining in our local queues
A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form