public class TransactionalProducerStream<T> extends AbstractProducerStream<T,TransactionalProducerStream<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 |
attributes, deliveryGuarantees, router, routingStrategy, sender, unroutableEventStrategy, unserializableEventStrategy| Constructor and Description |
|---|
TransactionalProducerStream(Supplier<RabbitEndpoint> endpoint,
reactor.core.publisher.Mono<Topology> topology,
Class<T> type,
SchemaManager schemaManager) |
| Modifier and Type | Method and Description |
|---|---|
protected reactor.core.publisher.Flux<reactor.rabbitmq.OutboundMessage> |
delayRetries(com.pivotal.rabbitmq.stream.OutboundMessageBuilder<T,TransactionalProducerStream<T>> messageBuilder,
reactor.core.publisher.Flux<reactor.rabbitmq.OutboundMessage> downstream) |
protected String |
getApplicationId() |
String |
getName() |
protected org.slf4j.Logger |
logger(String stream) |
<R extends Transaction<T>> |
send(reactor.core.publisher.Flux<R> stream) |
protected <R extends Transaction<T>> |
send(reactor.core.publisher.Flux<R> stream,
reactor.rabbitmq.SendOptions sendOptions) |
protected void |
setCodec(Codec<T> codec) |
getMaxInFlight, newSendOptions, resolveCodec, resolveSender, route, routeWith, trackReturnedMessages, whenNackByBroker, whenUnroutable, whenUnserializable, withAttributes, withAttributes, withCodec, withMaxInFight, withNameprotected 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 TransactionalProducerStream(Supplier<RabbitEndpoint> endpoint, reactor.core.publisher.Mono<Topology> topology, Class<T> type, SchemaManager schemaManager)
public <R extends Transaction<T>> reactor.core.publisher.Flux<R> send(reactor.core.publisher.Flux<R> stream)
protected <R extends Transaction<T>> reactor.core.publisher.Flux<R> send(reactor.core.publisher.Flux<R> stream, reactor.rabbitmq.SendOptions sendOptions)
protected reactor.core.publisher.Flux<reactor.rabbitmq.OutboundMessage> delayRetries(com.pivotal.rabbitmq.stream.OutboundMessageBuilder<T,TransactionalProducerStream<T>> messageBuilder, reactor.core.publisher.Flux<reactor.rabbitmq.OutboundMessage> downstream)
protected org.slf4j.Logger logger(String stream)
public String getName()
protected String getApplicationId()
protected void setCodec(Codec<T> codec)
Copyright © 2021. All rights reserved.