public abstract class AbstractProducerStream<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> extends Object
Modifier and Type | Field and Description |
---|---|
protected EventAttributes<T,P> |
attributes |
protected Codec<T> |
codec |
protected EventFailureStrategy<T,P> |
deliveryGuarantees |
protected Supplier<RabbitEndpoint> |
endpoint |
protected org.slf4j.Logger |
log |
protected String |
name |
static char |
PARTITION_SEPARATOR_CHARACTER |
protected BiConsumer<EventMessageBuilder,T> |
router |
protected RoutingStrategies<T,P> |
routingStrategy |
protected SchemaManager |
schemaManager |
protected reactor.rabbitmq.Sender |
sender |
protected Class<T> |
streamType |
protected reactor.core.publisher.Mono<Topology> |
topology |
protected UnroutableEventHandling<T,P> |
unroutableEventStrategy |
protected UnserializableEventHandling<T,P> |
unserializableEventStrategy |
Constructor and Description |
---|
AbstractProducerStream(Supplier<RabbitEndpoint> endpoint,
reactor.core.publisher.Mono<Topology> topology,
String name,
Class<T> type,
SchemaManager schemaManager) |
Modifier and Type | Method and Description |
---|---|
protected String |
getApplicationId() |
protected int |
getMaxInFlight(reactor.rabbitmq.SendOptions sendOptions) |
String |
getName() |
protected abstract org.slf4j.Logger |
logger(String stream) |
protected reactor.rabbitmq.SendOptions |
newSendOptions() |
protected Codec<T> |
resolveCodec() |
protected reactor.rabbitmq.Sender |
resolveSender() |
RoutingStrategies<T,P> |
route() |
P |
routeWith(BiConsumer<EventMessageBuilder,T> router) |
protected void |
setCodec(Codec<T> codec) |
protected boolean |
trackReturnedMessages() |
EventFailureStrategy<T,P> |
whenNackByBroker() |
UnroutableEventHandling<T,P> |
whenUnroutable() |
UnserializableEventHandling<T,P> |
whenUnserializable() |
EventAttributes<T,P> |
withAttributes() |
EventAttributes<T,P> |
withAttributes(boolean propagate) |
P |
withCodec(Codec codec) |
P |
withMaxInFight(Integer value) |
P |
withName(String name) |
protected EventAttributes<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> attributes
protected RoutingStrategies<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> routingStrategy
protected EventFailureStrategy<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> deliveryGuarantees
protected UnroutableEventHandling<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> unroutableEventStrategy
protected UnserializableEventHandling<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> unserializableEventStrategy
protected reactor.rabbitmq.Sender sender
protected BiConsumer<EventMessageBuilder,T> router
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 AbstractProducerStream(Supplier<RabbitEndpoint> endpoint, reactor.core.publisher.Mono<Topology> topology, String name, Class<T> type, SchemaManager schemaManager)
public EventAttributes<T,P> withAttributes()
public EventAttributes<T,P> withAttributes(boolean propagate)
public RoutingStrategies<T,P> route()
public P routeWith(BiConsumer<EventMessageBuilder,T> router)
public UnroutableEventHandling<T,P> whenUnroutable()
public EventFailureStrategy<T,P> whenNackByBroker()
public UnserializableEventHandling<T,P> whenUnserializable()
protected reactor.rabbitmq.SendOptions newSendOptions()
protected boolean trackReturnedMessages()
protected int getMaxInFlight(reactor.rabbitmq.SendOptions sendOptions)
protected reactor.rabbitmq.Sender resolveSender()
public String getName()
protected String getApplicationId()
protected void setCodec(Codec<T> codec)
protected abstract org.slf4j.Logger logger(String stream)
Copyright © 2021. All rights reserved.