public class ConsumerStream<T> extends AbstractConsumerStream<T,T>
Modifier and Type | Field and Description |
---|---|
protected Codec<T> |
codec |
protected Supplier<RabbitEndpoint> |
endpoint |
protected org.slf4j.Logger |
log |
protected String |
name |
static char |
PARTITION_SEPARATOR_CHARACTER |
protected SchemaManager |
schemaManager |
protected Class<T> |
streamType |
protected reactor.core.publisher.Mono<Topology> |
topology |
CONSUMER_TAG_SEPARATOR_CHARACTER, consumerTagSequence, MAX_CONSUMER_TAG_LENGTH, prefetch, queueName, receiver
Constructor and Description |
---|
ConsumerStream(Supplier<RabbitEndpoint> endpoint,
reactor.core.publisher.Mono<Topology> topology,
Class<T> type,
SchemaManager schemaManager,
String queueName) |
Modifier and Type | Method and Description |
---|---|
protected String |
getApplicationId() |
String |
getName() |
protected org.slf4j.Logger |
logger(String stream) |
protected reactor.core.publisher.Flux<T> |
receiveFromPartitionedQueue(Collection<reactor.rabbitmq.QueueSpecification> queuePartitions) |
protected reactor.core.publisher.Flux<T> |
receiveFromSingleQueue() |
protected Codec<T> |
resolveCodec() |
protected void |
setCodec(Codec<T> codec) |
IllegalEventHandler<T,ConsumerStream<T>> |
whenReceiveIllegalMessages() |
AvroCodecConfigurer<T,ConsumerStream<T>> |
withAvroCodec() |
consumeOptions, defaultConsumerSettings, receive, resolveReceiver, toEventType
protected String name
protected Class<T> streamType
protected Codec<T> codec
protected SchemaManager schemaManager
protected reactor.core.publisher.Mono<Topology> topology
protected Supplier<RabbitEndpoint> endpoint
protected final org.slf4j.Logger log
public static final char PARTITION_SEPARATOR_CHARACTER
public ConsumerStream(Supplier<RabbitEndpoint> endpoint, reactor.core.publisher.Mono<Topology> topology, Class<T> type, SchemaManager schemaManager, String queueName)
public IllegalEventHandler<T,ConsumerStream<T>> whenReceiveIllegalMessages()
public AvroCodecConfigurer<T,ConsumerStream<T>> withAvroCodec()
protected reactor.core.publisher.Flux<T> receiveFromSingleQueue()
receiveFromSingleQueue
in class AbstractConsumerStream<T,T>
protected reactor.core.publisher.Flux<T> receiveFromPartitionedQueue(Collection<reactor.rabbitmq.QueueSpecification> queuePartitions)
receiveFromPartitionedQueue
in class AbstractConsumerStream<T,T>
protected org.slf4j.Logger logger(String stream)
public String getName()
protected String getApplicationId()
protected void setCodec(Codec<T> codec)
Copyright © 2021. All rights reserved.