Interface ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T>
- Type Parameters:
T
- the message payload type
- All Superinterfaces:
ReactiveMessagePipelineBuilder<T>
,ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder<T>
- Enclosing interface:
- ReactiveMessagePipelineBuilder<T>
public static interface ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T>
extends ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder<T>
Builder interface for a pipeline that handles messages with concurrent one-by-one
messages handlers.
-
Nested Class Summary
Nested classes/interfaces inherited from interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T>, ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder<T>
-
Method Summary
Modifier and TypeMethodDescriptiongroupOrderedProcessing
(MessageGroupingFunction groupingFunction) Sets a function to group messages to be sent to the same message handler.maxInflight
(int maxInflight) Sets a global limit to the number of messages in-flight over all the concurrent handlers.Sets whether messages with the same key should be sent in order to the same message handler.Methods inherited from interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
build, messageHandler, pipelineRetrySpec, streamingMessageHandler, transformPipeline
Methods inherited from interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder
concurrency, errorLogger, handlingTimeout
-
Method Details
-
useKeyOrderedProcessing
ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T> useKeyOrderedProcessing()Sets whether messages with the same key should be sent in order to the same message handler.- Returns:
- the pipeline instance builder
-
groupOrderedProcessing
ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T> groupOrderedProcessing(MessageGroupingFunction groupingFunction) Sets a function to group messages to be sent to the same message handler.- Parameters:
groupingFunction
- the function used to group the messages- Returns:
- the pipeline instance builder
-
maxInflight
ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T> maxInflight(int maxInflight) Sets a global limit to the number of messages in-flight over all the concurrent handlers.- Parameters:
maxInflight
- the maximum in-flight messages- Returns:
- the pipeline instance builder
-