Skip navigation links
A B C D E F G H I J L M N O P Q R S T U V W 

A

AbstractConsumerStream<T,R> - Class in com.pivotal.rabbitmq.stream
 
AbstractConsumerStream(Supplier<RabbitEndpoint>, Mono<Topology>, Class<T>, SchemaManager, String) - Constructor for class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
AbstractProducerStream<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
AbstractProducerStream(Supplier<RabbitEndpoint>, Mono<Topology>, String, Class<T>, SchemaManager) - Constructor for class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
ackBatchTimeout - Variable in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
ackEvery(int, Duration) - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
ackOrRetryNack(OutboundMessageResult, SynchronousSink<OutboundMessageResult>) - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 
addDefaultRabbitEndpoint() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
addRabbitEndpoint(RabbitProperties) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
addRabbitEndpoint(String, RabbitProperties) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
AdvancedProperties - Class in com.pivotal.rabbitmq
 
AdvancedProperties() - Constructor for class com.pivotal.rabbitmq.AdvancedProperties
 
allBindingKeys(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
alwaysPersistent() - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
alwaysReject() - Method in class com.pivotal.rabbitmq.stream.IllegalTransactionalEventHandler
 
alwaysRetry(Duration) - Method in class com.pivotal.rabbitmq.stream.EventFailureStrategy
 
alwaysRetry(Duration) - Method in class com.pivotal.rabbitmq.stream.UnroutableEventHandling
 
alwaysTerminate() - Method in class com.pivotal.rabbitmq.stream.IllegalTransactionalEventHandler
 
AMQP_PORT - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
AMQP_SCHEME - Static variable in class com.pivotal.rabbitmq.RabbitAddress
 
amqpConnectionErrors() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
amqpName - Variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
AMQPS_PORT - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
AMQPS_SCHEME - Static variable in class com.pivotal.rabbitmq.RabbitAddress
 
and() - Method in class com.pivotal.rabbitmq.stream.BaseStreamConfigurer
 
and() - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
and() - Method in class com.pivotal.rabbitmq.topology.Exchange
 
and() - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
and() - Method in class com.pivotal.rabbitmq.topology.Queue
 
and() - Method in interface com.pivotal.rabbitmq.topology.QuorumQueue
 
anyAddressSecure() - Method in class com.pivotal.rabbitmq.RabbitProperties
Returns true if this endpoint uses TLS for AMQP or the management api.
applicationId(String, Optional<String>) - Static method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
areAddressesSecure() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
areManagementAddressesSecure() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
attributes - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
AVRO_FORMAT - Static variable in class com.pivotal.rabbitmq.schema.SchemaManager
 
AvroCodec<T> - Class in com.pivotal.rabbitmq.schema
 
AvroCodecConfigurer<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
AvroCodecConfigurer(P) - Constructor for class com.pivotal.rabbitmq.stream.AvroCodecConfigurer
 

B

BaseStreamConfigurer<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
BaseStreamConfigurer(P) - Constructor for class com.pivotal.rabbitmq.stream.BaseStreamConfigurer
 
batchAckSize - Variable in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
bcc(String...) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
bcc(Function<T, String>) - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
bindExchange(BindingSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
bindQueue(BindingSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
boundTo(String) - Method in class com.pivotal.rabbitmq.topology.Exchange
 
boundTo(String, String...) - Method in class com.pivotal.rabbitmq.topology.Exchange
 
boundTo(String) - Method in class com.pivotal.rabbitmq.topology.Queue
 
boundTo(String, String...) - Method in class com.pivotal.rabbitmq.topology.Queue
 
boundTo(String, MessageSelector) - Method in class com.pivotal.rabbitmq.topology.Queue
 
BroadcastTopology - Class in com.pivotal.rabbitmq.topologies
All messages sent by the producerApp are received by all subscribers.
BroadcastTopology(String) - Constructor for class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
BroadcastTopology(String, BroadcastTopology.SubscriberProperties) - Constructor for class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
BroadcastTopology.SubscriberProperties - Class in com.pivotal.rabbitmq.topologies
 
build() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
build() - Method in class com.pivotal.rabbitmq.topology.TopologyBuilder
 
buildOutboundMessage(OutboundMessageBuilder<T, ProducerStream<T>>) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
 

C

cc(String...) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
cc(Function<T, String>) - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
classic() - Method in class com.pivotal.rabbitmq.topology.Queue
 
ClassicQueue - Interface in com.pivotal.rabbitmq.topology
 
close() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
close() - Method in class com.pivotal.rabbitmq.ReactiveRabbit
 
Codec<T> - Interface in com.pivotal.rabbitmq.schema
 
com.pivotal.rabbitmq - package com.pivotal.rabbitmq
 
com.pivotal.rabbitmq.schema - package com.pivotal.rabbitmq.schema
 
com.pivotal.rabbitmq.source - package com.pivotal.rabbitmq.source
 
com.pivotal.rabbitmq.stream - package com.pivotal.rabbitmq.stream
 
com.pivotal.rabbitmq.topologies - package com.pivotal.rabbitmq.topologies
 
com.pivotal.rabbitmq.topology - package com.pivotal.rabbitmq.topology
 
com.pivotal.rabbitmq.utils - package com.pivotal.rabbitmq.utils
 
commit() - Method in interface com.pivotal.rabbitmq.stream.Transaction
Call this method when the application has completed processing the Transaction which actually means acking the event which originated it.
commit() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
commitElseRejectAndDiscard(Predicate<T>) - Static method in class com.pivotal.rabbitmq.ReactiveRabbit
 
commitElseTerminate() - Static method in class com.pivotal.rabbitmq.ReactiveRabbit
 
compareTo(Version) - Method in class com.pivotal.rabbitmq.stream.Version
 
consistent_hash - Static variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
consumeOptions() - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
consumeOptions() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
CONSUMER_TAG_SEPARATOR_CHARACTER - Static variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
ConsumerStream<T> - Class in com.pivotal.rabbitmq.stream
 
ConsumerStream(Supplier<RabbitEndpoint>, Mono<Topology>, Class<T>, SchemaManager, String) - Constructor for class com.pivotal.rabbitmq.stream.ConsumerStream
 
consumerTagSequence - Static variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
coordinate(List<QueueInfo>) - Method in class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
createConsumerStream(String, Class<T>) - Method in class com.pivotal.rabbitmq.stream.StreamBuilder
 
createProducerStream(Class<T>) - Method in class com.pivotal.rabbitmq.stream.StreamBuilder
 
createReceiver() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
createSender() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
createTransactionalConsumerStream(String, Class<T>) - Method in class com.pivotal.rabbitmq.stream.StreamBuilder
 
createTransactionalProducerStream(Class<T>) - Method in class com.pivotal.rabbitmq.stream.StreamBuilder
 

D

declare(Topology) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.TopologyManagerImpl
 
declare(Consumer<TopologyBuilder>) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.TopologyManagerImpl
 
declare(QueueSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
declare(ExchangeSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
declare(PolicyInfo) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
declare(Topology, RabbitEndpoint) - Method in class com.pivotal.rabbitmq.topology.TopologyConfigurer
 
declare(Topology) - Method in interface com.pivotal.rabbitmq.topology.TopologyManager
 
declare(Consumer<TopologyBuilder>) - Method in interface com.pivotal.rabbitmq.topology.TopologyManager
 
declareExchange(String) - Method in class com.pivotal.rabbitmq.topology.TopologyBuilder
 
declarePassively(Consumer<TopologyBuilder>) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.TopologyManagerImpl
 
declarePassively(Consumer<TopologyBuilder>) - Method in interface com.pivotal.rabbitmq.topology.TopologyManager
 
declareQueue(String) - Method in class com.pivotal.rabbitmq.topology.TopologyBuilder
 
declareTopology(Consumer<TopologyBuilder>) - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
Returns a StreamBuilder configured to declare, just in time, a topology using the provided TopologyBuilder.
declareTopology(Topology) - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
Returns a StreamBuilder configured to declare, just in time, a topology that we have previously built using ReactiveRabbit.newTopologyBuilder() method.
declareTopology(Consumer<TopologyBuilder>) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
declareTopology(Topology) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
declareTopologyPassively(Consumer<TopologyBuilder>) - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
 
declareTopologyPassively(Consumer<TopologyBuilder>) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
decode(String, InputStream) - Method in class com.pivotal.rabbitmq.schema.AvroCodec
 
decode(String, InputStream) - Method in interface com.pivotal.rabbitmq.schema.Codec
 
DEFAULT_KEY_STORE_ALGORITHM - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
DEFAULT_KEY_STORE_TYPE - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
DEFAULT_PASSWORD - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
DEFAULT_TRUST_STORE_TYPE - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
DEFAULT_USERNAME - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
DEFAULT_VIRTUAL_HOST - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
defaultConsumerSettings() - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
defaultConsumerSettings() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
DefaultReactiveClient - Class in com.pivotal.rabbitmq.topology
 
DefaultReactiveClient(RabbitEndpoint) - Constructor for class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
delayRetries(OutboundMessageBuilder<T, ProducerStream<T>>, Flux<OutboundMessage>) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
 
delayRetries(OutboundMessageBuilder<T, TransactionalProducerStream<T>>, Flux<OutboundMessage>) - Method in class com.pivotal.rabbitmq.stream.TransactionalProducerStream
 
delete(Topology) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.TopologyManagerImpl
 
delete(QueueSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
delete(ExchangeSpecification) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
delete(PolicyInfo) - Method in class com.pivotal.rabbitmq.topology.DefaultReactiveClient
 
delete(Topology, RabbitEndpoint) - Method in class com.pivotal.rabbitmq.topology.TopologyConfigurer
 
delete(Topology) - Method in interface com.pivotal.rabbitmq.topology.TopologyManager
 
deliveryGuarantees - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
direct - Static variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
durable(boolean) - Method in class com.pivotal.rabbitmq.topology.Queue
 

E

elseCommit() - Method in class com.pivotal.rabbitmq.TransactionRollbackStrategy
 
encode(T, OutputStream) - Method in class com.pivotal.rabbitmq.schema.AvroCodec
 
encode(T, OutputStream) - Method in interface com.pivotal.rabbitmq.schema.Codec
 
equals(Object) - Method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
equals(Object) - Method in class com.pivotal.rabbitmq.stream.Version
 
equals(Object) - Method in class com.pivotal.rabbitmq.topology.MessageSelector
 
EventAttributes<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
EventFailureStrategy<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
EventFailureStrategy(P) - Constructor for class com.pivotal.rabbitmq.stream.EventFailureStrategy
 
EventMessageBuilder - Interface in com.pivotal.rabbitmq.stream
 
EVERYTHING - Static variable in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
Exchange - Class in com.pivotal.rabbitmq.topology
 
ExchangeType - Class in com.pivotal.rabbitmq.topology
 

F

fanout - Static variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
fetch(String, int) - Method in interface com.pivotal.rabbitmq.schema.SchemaRegistryClient
fetch schema by its subject name and version and returns
fetch(String) - Method in interface com.pivotal.rabbitmq.schema.SchemaRegistryClient
fetch all schema versions by its subject name
fetch(String, int) - Method in class com.pivotal.rabbitmq.schema.SpringSchemaRegistryClient
 
fetch(String) - Method in class com.pivotal.rabbitmq.schema.SpringSchemaRegistryClient
 
fetchReadSchemaByContentType(String) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
fetchSchemaByFullName(String) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
findBindingsByExchangeName(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findBindingsByQueueName(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findBindingsByQueueNameAndExchange(String, String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findExchange(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findExchangeBindingsByExchangeFrom(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findExchangePolicy(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findPolicy(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findQueue(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findQueuePartition(String, int) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findQueuePartitions(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findQueuePolicy(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
findSingleRootExchange() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
firstBinding(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
firstExchangeBinding(String) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
FluxSources - Class in com.pivotal.rabbitmq.utils
 
FluxSources() - Constructor for class com.pivotal.rabbitmq.utils.FluxSources
 
forApplication(String) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
forProducer() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
forProducer() - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
forSubscriber(String) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
forSubscriber(String, BroadcastTopology.SubscriberProperties) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
forSubscriber(String, String...) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
forSubscriber(String, MulticastTopology.SubscriberProperties, String...) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
from(String, AcknowledgableDelivery) - Static method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
from(String, long) - Static method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
from(OutboundMessage) - Static method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
fromWeb(URI) - Static method in class com.pivotal.rabbitmq.utils.FluxSources
 

G

genericSchemaReaderFullName(String) - Method in class com.pivotal.rabbitmq.stream.AvroCodecConfigurer
To deserialize an event onto a GenericRecord use this schemaReader.
genericSchemaReaderMimeType(String) - Method in class com.pivotal.rabbitmq.stream.AvroCodecConfigurer
To deserialize an event onto a GenericRecord use this schemaReader.
get() - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
Returns the actual RabbitEndpoint used to deliver this service.
get() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
get() - Method in interface com.pivotal.rabbitmq.stream.Transaction
Every Transaction carries a business event
get() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
getAddresses() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
Returns the string holding the list of comma-separated AMQP addresses
getAddresses() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getAdvanced() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getAdvanced() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getAlgorithm() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getAMQPQueuePattern(String) - Static method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
getApplicationId() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
getApplicationId() - Method in class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
getBindings() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getConnection() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
Connection Retry settings for AMQP and HTTP protocol
getConnection() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getContentType() - Method in exception com.pivotal.rabbitmq.schema.MissingAvroSchemaException
 
getContentType() - Method in class com.pivotal.rabbitmq.schema.SchemaReference
 
getContentTypeForUnversionedSchema(String, String) - Static method in class com.pivotal.rabbitmq.schema.SchemaManager
 
getContentTypeForVersionedSchema(String, String, int) - Static method in class com.pivotal.rabbitmq.schema.SchemaManager
 
getEventType() - Method in exception com.pivotal.rabbitmq.schema.IncompatibleEventTypeException
 
getExchangeBindings() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getExchanges() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getFirstBackoff() - Method in class com.pivotal.rabbitmq.RandomBackoffProperties
 
getHost() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getHost() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getId() - Method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
getKeyStore() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getKeyStoreAlgorithm() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getKeyStorePassword() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getKeyStoreType() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getManagementAddresses() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
Returns the string holding the list of comma-separated HTTP addresses
getManagementAddresses() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getManagementAPI() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
getManagementAPI() - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
 
getManagementAPI() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
getManagementPassword() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getManagementPort() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getManagementUsername() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getMaxBackoff() - Method in class com.pivotal.rabbitmq.RandomBackoffProperties
 
getMaxInFlight(SendOptions) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
getMaxQueueLength() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
getMaxQueueLength() - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
getMessage() - Method in exception com.pivotal.rabbitmq.topology.ResourceNotAvailableException
 
getName() - Method in class com.pivotal.rabbitmq.schema.SchemaReference
 
getName() - Method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
getName() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
getName() - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
getName() - Method in class com.pivotal.rabbitmq.topology.Exchange
 
getName() - Method in class com.pivotal.rabbitmq.topology.Queue
 
getPartitionCount() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
getPartitionCount() - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
getPartitionExchangeName(String) - Static method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
getPassword() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getPassword() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getPassword() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getPendingCommits() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
getPolicies() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getPolicyName(String) - Static method in class com.pivotal.rabbitmq.topology.Queue
 
getPort() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getPort() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getPreferredManagementSecure() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getPreferredSecure() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getProperties() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
getProperties() - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
Returns the RabbitEndpoint's settings such as connection settings
getProperties() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
getProtocol() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getQueueBindings() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getQueues() - Method in interface com.pivotal.rabbitmq.topology.Topology
 
getRandomBackoff() - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
getReason() - Method in exception com.pivotal.rabbitmq.schema.IncompatibleEventSchemaException
 
getRegistryURL() - Method in class com.pivotal.rabbitmq.SchemaProperties
 
getReplicas() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
getReplicas() - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
getRetryMax() - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
getRootSchemaFolder() - Method in class com.pivotal.rabbitmq.SchemaProperties
 
getSchema() - Method in class com.pivotal.rabbitmq.schema.SchemaReference
 
getSchemaFilenames() - Method in class com.pivotal.rabbitmq.SchemaProperties
 
getSchemaRegistryStrategy() - Method in class com.pivotal.rabbitmq.SchemaProperties
 
getSecureRandom() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getSendRetryDelay() - Method in class com.pivotal.rabbitmq.stream.EventFailureStrategy
 
getSsl() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getSsl() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getStrategy() - Method in class com.pivotal.rabbitmq.stream.UnroutableEventHandling
 
getStrategy() - Method in class com.pivotal.rabbitmq.stream.UnserializableEventHandling
 
getStreamOfPartitionsToRelease() - Method in class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
getStreamType() - Method in exception com.pivotal.rabbitmq.schema.IncompatibleEventTypeException
 
getTimeout() - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
getTopology() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
Returns Topology Retry settings when it is not available or when it is possible to declare it.
getTopology() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getTrustStore() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getTrustStorePassword() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getTrustStoreType() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
getType() - Method in class com.pivotal.rabbitmq.topology.Exchange
 
getUnexpectedContentType() - Method in exception com.pivotal.rabbitmq.schema.IncompatibleEventSchemaException
 
getUsername() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getUsername() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getUsername() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getValue() - Method in class com.pivotal.rabbitmq.topology.ExchangeType
 
getValue() - Method in enum com.pivotal.rabbitmq.topology.Queue.MaxLengthStrategy
 
getVersion() - Method in class com.pivotal.rabbitmq.schema.SchemaReference
 
getVirtualHost() - Method in class com.pivotal.rabbitmq.RabbitAddress
 
getVirtualHost() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
getVirtualHost() - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
getVirtualHost() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
getWithDeadLetterQueue() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 

H

hasExchangeSelector() - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
hashCode() - Method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
hashCode() - Method in class com.pivotal.rabbitmq.stream.Version
 
hashCode() - Method in class com.pivotal.rabbitmq.topology.MessageSelector
 
hasRoutingKeySelector() - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
header(String, Function<T, ? extends Object>) - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
header(String, T) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
headers - Static variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
hookOnCancel() - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 
hookOnComplete() - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 
hookOnError(Throwable) - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 
hookOnNext(OutboundMessage) - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 
hookOnSubscribe(Subscription) - Method in class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 

I

id() - Method in interface com.pivotal.rabbitmq.stream.Transaction
Every Transaction has an identifier
id() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
Identifier(String, long) - Constructor for class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
Identifier(Transactional.Identifier, long) - Constructor for class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
ignore - Static variable in class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
ignore() - Method in class com.pivotal.rabbitmq.stream.UnroutableEventHandling
 
IllegalEventHandler<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
IllegalEventHandler(P) - Constructor for class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
IllegalTransactionalEventHandler<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
IllegalTransactionalEventHandler(P, Consumer<Transaction<?>>, Consumer<Transaction<?>>) - Constructor for class com.pivotal.rabbitmq.stream.IllegalTransactionalEventHandler
 
importSchema(File) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
importSchema(Schema) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
importSchema(InputStream) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
IncompatibleEventSchemaException - Exception in com.pivotal.rabbitmq.schema
 
IncompatibleEventSchemaException(String, String) - Constructor for exception com.pivotal.rabbitmq.schema.IncompatibleEventSchemaException
 
IncompatibleEventTypeException - Exception in com.pivotal.rabbitmq.schema
 
IncompatibleEventTypeException(Class<?>, Class<?>) - Constructor for exception com.pivotal.rabbitmq.schema.IncompatibleEventTypeException
 
is(Class<? extends Throwable>) - Static method in class com.pivotal.rabbitmq.RabbitEndpoint
 
isAutoLoadSchemas() - Method in class com.pivotal.rabbitmq.SchemaProperties
 
isChannelShouldCheckRpcResponseType() - Method in class com.pivotal.rabbitmq.AdvancedProperties
 
isDurable() - Method in class com.pivotal.rabbitmq.topology.Queue
 
isPropagateAttributeFromEvent() - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
isValidateServerCertificate() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
isVerifyHostname() - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 

J

JKS - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
Trust Store type

L

lazy() - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
lines(URI) - Static method in class com.pivotal.rabbitmq.utils.FluxSources
 
listOfReferencedExchanges() - Method in class com.pivotal.rabbitmq.topology.Exchange
 
log - Static variable in class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
logger(String) - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
logger(String) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
 
logger(String) - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
logger(String) - Method in class com.pivotal.rabbitmq.stream.TransactionalProducerStream
 

M

MANAGEMENT_PORT - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
managementConnectionErrors() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
manageTopologies() - Method in interface com.pivotal.rabbitmq.RabbitEndpointService
In cases when you only need to declare and/or delete your topologies, you get a from which you can declare or delete an entire topology.
manageTopologies() - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
map(R) - Method in interface com.pivotal.rabbitmq.stream.Transaction
Every Transaction carries a business event however this event may be transformed onto another business event.
map(R) - Method in class com.pivotal.rabbitmq.stream.Transactional
 
mapIfApply(ShutdownSignalException) - Static method in exception com.pivotal.rabbitmq.topology.ResourceNotAvailableException
 
matchAll() - Static method in class com.pivotal.rabbitmq.topology.MessageSelector
 
matchAny() - Static method in class com.pivotal.rabbitmq.topology.MessageSelector
 
MAX_CONSUMER_TAG_LENGTH - Static variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
MaxLengthStrategy - Enum in com.pivotal.rabbitmq.topology
 
mergeWith(Topology) - Method in interface com.pivotal.rabbitmq.topology.Topology
 
messageId(Function<T, String>) - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
messageId(String) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
MessageSelector - Class in com.pivotal.rabbitmq.topology
 
MissingAvroSchemaException - Exception in com.pivotal.rabbitmq.schema
 
MissingAvroSchemaException(String) - Constructor for exception com.pivotal.rabbitmq.schema.MissingAvroSchemaException
 
MissingBodyException - Exception in com.pivotal.rabbitmq.stream
 
MissingBodyException() - Constructor for exception com.pivotal.rabbitmq.stream.MissingBodyException
 
MissingContentTypeException - Exception in com.pivotal.rabbitmq.stream
 
MissingContentTypeException() - Constructor for exception com.pivotal.rabbitmq.stream.MissingContentTypeException
 
MulticastTopology - Class in com.pivotal.rabbitmq.topologies
{producerAPP} {subscriber1-app} | | \/ \/ --(bindingKeys1)--> [queue:subscriber1] +----------(bindingKeys2)--------> [queue:subscriber2-1] ..
MulticastTopology(String) - Constructor for class com.pivotal.rabbitmq.topologies.MulticastTopology
 
MulticastTopology(String, MulticastTopology.SubscriberProperties) - Constructor for class com.pivotal.rabbitmq.topologies.MulticastTopology
 
MulticastTopology.SubscriberProperties - Class in com.pivotal.rabbitmq.topologies
 

N

name - Variable in class com.pivotal.rabbitmq.topology.Queue
 
neverRetry() - Method in class com.pivotal.rabbitmq.stream.EventFailureStrategy
 
newAvroCodec(Class<T>) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
newAvroCodec(Class<T>, Schema) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
newInstance() - Static method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
newRecord(String) - Method in class com.pivotal.rabbitmq.schema.SchemaManager
 
newSendOptions() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
newSubscriberProperties() - Static method in class com.pivotal.rabbitmq.topologies.BroadcastTopology
 
newSubscriberProperties() - Static method in class com.pivotal.rabbitmq.topologies.MulticastTopology
 
newTopologyBuilder() - Method in class com.pivotal.rabbitmq.ReactiveRabbit
 
newTransaction(T) - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
newTransaction(T, CompletableFuture<T>) - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
newTransaction() - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
NON_ROUTING_KEY - Static variable in class com.pivotal.rabbitmq.topology.Queue
 
NONE - Static variable in class com.pivotal.rabbitmq.topology.TopologyBuilder
 
nonPersistent() - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 

O

of(long) - Method in class com.pivotal.rabbitmq.stream.Version
 
of(String, Object) - Method in class com.pivotal.rabbitmq.topology.MessageSelector
 
ofAnyType(Consumer<Throwable>) - Method in class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
ofType(Class<? extends Throwable>, Consumer<Throwable>) - Method in class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
OnDemandSource<T> - Class in com.pivotal.rabbitmq.source
 
OnDemandSource(String) - Constructor for class com.pivotal.rabbitmq.source.OnDemandSource
 
OutboundMessageSubscriber - Class in com.pivotal.rabbitmq.stream
 
OutboundMessageSubscriber(Sinks.Many<OutboundMessage>, Integer, boolean) - Constructor for class com.pivotal.rabbitmq.stream.OutboundMessageSubscriber
 

P

parent - Variable in class com.pivotal.rabbitmq.stream.BaseStreamConfigurer
 
parse(String) - Static method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
PartitionCoordinator - Class in com.pivotal.rabbitmq.stream
Single threaded
PartitionCoordinator(String, String, int, Supplier<RabbitEndpoint>, Duration, Flux<String>) - Constructor for class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
PartitionSpecification - Class in com.pivotal.rabbitmq.topology
 
passive(boolean) - Method in class com.pivotal.rabbitmq.topology.Exchange
 
passive(boolean) - Method in class com.pivotal.rabbitmq.topology.Queue
 
persistent(Function<T, Boolean>) - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
Pipeline<T,R> - Interface in com.pivotal.rabbitmq.source
 
PKCS12 - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
Key Store type
policyName(String) - Static method in class com.pivotal.rabbitmq.topology.Exchange
 
policyName - Variable in class com.pivotal.rabbitmq.topology.Queue
 
policyPattern() - Method in class com.pivotal.rabbitmq.topology.Queue
 
prefetch - Variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
ProducerStream<T> - Class in com.pivotal.rabbitmq.stream
 
ProducerStream(Supplier<RabbitEndpoint>, Mono<Topology>, Class<T>, SchemaManager) - Constructor for class com.pivotal.rabbitmq.stream.ProducerStream
 
propagate(boolean) - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
putTransaction(R) - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 

Q

Queue - Class in com.pivotal.rabbitmq.topology
 
Queue.MaxLengthStrategy - Enum in com.pivotal.rabbitmq.topology
 
queueName - Variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
QueueType - Enum in com.pivotal.rabbitmq.topology
 
quorum() - Method in class com.pivotal.rabbitmq.topology.Queue
 
QuorumQueue - Interface in com.pivotal.rabbitmq.topology
 

R

RabbitAddress - Class in com.pivotal.rabbitmq
 
RabbitAddress(String) - Constructor for class com.pivotal.rabbitmq.RabbitAddress
 
RabbitAddress(String, String, Integer, String, String, String) - Constructor for class com.pivotal.rabbitmq.RabbitAddress
 
RabbitEndpoint - Class in com.pivotal.rabbitmq
 
RabbitEndpoint(String, Supplier<String>, Supplier<String>, RabbitProperties) - Constructor for class com.pivotal.rabbitmq.RabbitEndpoint
 
RabbitEndpointSelectorImpl(Supplier<RabbitEndpoint>, SchemaManager) - Constructor for class com.pivotal.rabbitmq.ReactiveRabbitBuilder.RabbitEndpointSelectorImpl
 
RabbitEndpointService - Interface in com.pivotal.rabbitmq
 
RabbitInputProperties - Class in com.pivotal.rabbitmq
 
RabbitInputProperties() - Constructor for class com.pivotal.rabbitmq.RabbitInputProperties
 
RabbitProperties - Class in com.pivotal.rabbitmq
 
RabbitProperties() - Constructor for class com.pivotal.rabbitmq.RabbitProperties
Build RabbitProperties using the default settings
RabbitProperties(RabbitInputProperties) - Constructor for class com.pivotal.rabbitmq.RabbitProperties
 
RabbitSslProperties - Class in com.pivotal.rabbitmq
 
RabbitSslProperties() - Constructor for class com.pivotal.rabbitmq.RabbitSslProperties
 
RandomBackoffProperties - Class in com.pivotal.rabbitmq
 
RandomBackoffProperties() - Constructor for class com.pivotal.rabbitmq.RandomBackoffProperties
 
ReactiveRabbit - Class in com.pivotal.rabbitmq
 
ReactiveRabbitBuilder - Class in com.pivotal.rabbitmq
 
ReactiveRabbitBuilder.RabbitEndpointSelectorImpl - Class in com.pivotal.rabbitmq
 
ReactiveRabbitBuilder.TopologyManagerImpl - Class in com.pivotal.rabbitmq
 
receive() - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
receiveFromPartitionedQueue(Collection<QueueSpecification>) - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
receiveFromPartitionedQueue(Collection<QueueSpecification>) - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
receiveFromPartitionedQueue(Collection<QueueSpecification>) - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
receiveFromSingleQueue() - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
receiveFromSingleQueue() - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
receiveFromSingleQueue() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
receiver - Variable in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
RedeliveryReason - Enum in com.pivotal.rabbitmq.stream
 
register(String, String) - Method in interface com.pivotal.rabbitmq.schema.SchemaRegistryClient
Register schema with subject and returns version and schema
register(String, String) - Method in class com.pivotal.rabbitmq.schema.SpringSchemaRegistryClient
 
reject() - Method in interface com.pivotal.rabbitmq.stream.Transaction
Same as calling Transaction.rollback(boolean) with `false` value
reject() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
reject() - Method in class com.pivotal.rabbitmq.stream.UnableBuildEventHandling
 
reject() - Method in class com.pivotal.rabbitmq.stream.UnserializableEventHandling
 
rejectWhen(Class<? extends Throwable>...) - Static method in class com.pivotal.rabbitmq.ReactiveRabbit
 
rejectWhen(Class<? extends Throwable>...) - Method in class com.pivotal.rabbitmq.TransactionRollbackStrategy
 
remove(Transactional.Identifier) - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
remove(OutboundMessageResult) - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
remove() - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
removeAndGet() - Method in class com.pivotal.rabbitmq.stream.TransactionManager
 
requeueWhen(Class<? extends Throwable>...) - Static method in class com.pivotal.rabbitmq.ReactiveRabbit
 
requeueWhen(Class<? extends Throwable>...) - Method in class com.pivotal.rabbitmq.TransactionRollbackStrategy
 
resolveCodec() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
resolveCodec() - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
resolveCodec() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
resolveReceiver() - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
resolveSender() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
ResourceNotAvailableException - Exception in com.pivotal.rabbitmq.topology
 
ResourceNotAvailableException(String, String, String) - Constructor for exception com.pivotal.rabbitmq.topology.ResourceNotAvailableException
 
RetryPolicyProperties - Class in com.pivotal.rabbitmq
 
RetryPolicyProperties() - Constructor for class com.pivotal.rabbitmq.RetryPolicyProperties
 
rollback(boolean) - Method in interface com.pivotal.rabbitmq.stream.Transaction
Call this method when the application did not successfully process the event.
rollback(boolean) - Method in class com.pivotal.rabbitmq.stream.Transactional
 
route() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
router - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
routeWith(BiConsumer<EventMessageBuilder, T>) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
RoutingStrategies<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
routingStrategy - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 

S

SCHEMA_NUMBER_PATTERN - Static variable in class com.pivotal.rabbitmq.schema.SchemaManager
 
schemaManager() - Method in class com.pivotal.rabbitmq.ReactiveRabbit
 
SchemaManager - Class in com.pivotal.rabbitmq.schema
 
SchemaManager() - Constructor for class com.pivotal.rabbitmq.schema.SchemaManager
 
SchemaManager(SchemaRegistryClient, SchemaManager.SchemaRegistryStrategy) - Constructor for class com.pivotal.rabbitmq.schema.SchemaManager
 
SchemaManager.SchemaRegistryStrategy - Enum in com.pivotal.rabbitmq.schema
 
SchemaProperties - Class in com.pivotal.rabbitmq
 
SchemaProperties() - Constructor for class com.pivotal.rabbitmq.SchemaProperties
 
SchemaReference - Class in com.pivotal.rabbitmq.schema
 
SchemaReference(String, Schema, Integer) - Constructor for class com.pivotal.rabbitmq.schema.SchemaReference
 
SchemaRegistryClient - Interface in com.pivotal.rabbitmq.schema
 
SECURE_MANAGEMENT_PORT - Static variable in class com.pivotal.rabbitmq.RabbitProperties
 
selectDefaultEndpoint() - Method in class com.pivotal.rabbitmq.ReactiveRabbit
 
selectEndpoint(String) - Method in class com.pivotal.rabbitmq.ReactiveRabbit
 
send(T) - Method in class com.pivotal.rabbitmq.source.OnDemandSource
 
send(T) - Method in interface com.pivotal.rabbitmq.source.Sender
 
send(Flux<T>) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
 
send(Flux<R>) - Method in class com.pivotal.rabbitmq.stream.TransactionalProducerStream
 
send(Flux<R>, SendOptions) - Method in class com.pivotal.rabbitmq.stream.TransactionalProducerStream
 
sendAndForget(Flux<T>) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
 
Sender<T> - Interface in com.pivotal.rabbitmq.source
 
sender - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
sendWithPublishConfirms(Flux<T>, SendOptions) - Method in class com.pivotal.rabbitmq.stream.ProducerStream
Flux stream --+--------> Flux streamToSend | newTx | \/ \/ transactionManager OutboundMessageSubscriber (FlowControl/Backpressure) | \/ Flux downstream <------+ | | \/ | Flux sentMessages = Sender.sendWithPublishConfirms()| | | \/ | Flux <--+acked--+---nacked-----------------------------------+ | removeTx \/ transactionManager
SerializationException - Exception in com.pivotal.rabbitmq.stream
 
SerializationException(Throwable) - Constructor for exception com.pivotal.rabbitmq.stream.SerializationException
 
setAddresses(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setAdvanced(AdvancedProperties) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setAlgorithm(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setAutoLoadSchemas(boolean) - Method in class com.pivotal.rabbitmq.SchemaProperties
 
setChannelShouldCheckRpcResponseType(boolean) - Method in class com.pivotal.rabbitmq.AdvancedProperties
 
setConnection(RetryPolicyProperties) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setFirstBackoff(Duration) - Method in class com.pivotal.rabbitmq.RandomBackoffProperties
 
setHost(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setKeyStore(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setKeyStoreAlgorithm(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setKeyStorePassword(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setKeyStoreType(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setManagementAddresses(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setManagementPort(Integer) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setMaxBackoff(Duration) - Method in class com.pivotal.rabbitmq.RandomBackoffProperties
 
setMaxQueueLength(Integer) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
setMaxQueueLength(Integer) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
setPartitionCount(Integer) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
setPartitionCount(Integer) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
setPassword(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setPort(Integer) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setPreferredManagementSecure(boolean) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setPreferredSecure(boolean) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setRandomBackoff(RandomBackoffProperties) - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
setRegistryURL(String) - Method in class com.pivotal.rabbitmq.SchemaProperties
 
setReplicas(Integer) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
setReplicas(Integer) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
setRetryMax(long) - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
setRootSchemaFolder(String) - Method in class com.pivotal.rabbitmq.SchemaProperties
 
setSchemaFilenames(String[]) - Method in class com.pivotal.rabbitmq.SchemaProperties
 
setSchemaRegistryStrategy(SchemaManager.SchemaRegistryStrategy) - Method in class com.pivotal.rabbitmq.SchemaProperties
 
setSecureRandom(SecureRandom) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setSsl(RabbitSslProperties) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setTimeout(Duration) - Method in class com.pivotal.rabbitmq.RetryPolicyProperties
 
setTopology(RetryPolicyProperties) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setTrustStore(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setTrustStorePassword(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setTrustStoreType(String) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setUsername(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setValidateServerCertificate(boolean) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setVerifyHostname(boolean) - Method in class com.pivotal.rabbitmq.RabbitSslProperties
 
setVirtualHost(String) - Method in class com.pivotal.rabbitmq.RabbitInputProperties
 
setWithDeadLetterQueue(Boolean) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
shouldRetry() - Method in class com.pivotal.rabbitmq.stream.EventFailureStrategy
 
shouldRetry() - Method in class com.pivotal.rabbitmq.stream.UnroutableEventHandling
 
shouldTerminate() - Method in class com.pivotal.rabbitmq.stream.UnserializableEventHandling
 
ShutdownPipelineException - Exception in com.pivotal.rabbitmq.stream
 
ShutdownPipelineException() - Constructor for exception com.pivotal.rabbitmq.stream.ShutdownPipelineException
 
source() - Method in class com.pivotal.rabbitmq.source.OnDemandSource
 
Source<T> - Interface in com.pivotal.rabbitmq.source
 
source() - Method in interface com.pivotal.rabbitmq.source.Source
 
spawn(R) - Method in interface com.pivotal.rabbitmq.stream.Transaction
Every Transaction carries a business event however we can span or split a single Transaction into two or many children Transactions all linked to the parent.
spawn(R) - Method in class com.pivotal.rabbitmq.stream.Transactional
 
SpringSchemaRegistryClient - Class in com.pivotal.rabbitmq.schema
 
SpringSchemaRegistryClient(HttpClient) - Constructor for class com.pivotal.rabbitmq.schema.SpringSchemaRegistryClient
 
start() - Method in class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
stop() - Method in class com.pivotal.rabbitmq.stream.PartitionCoordinator
 
StreamBuilder - Class in com.pivotal.rabbitmq.stream
 
StreamBuilder(Supplier<RabbitEndpoint>, Mono<Topology>, SchemaManager) - Constructor for class com.pivotal.rabbitmq.stream.StreamBuilder
 
submit(T) - Method in interface com.pivotal.rabbitmq.source.Pipeline
 
SubscriberProperties() - Constructor for class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
SubscriberProperties() - Constructor for class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
SunX509 - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
supportedPrimitiveTypes - Static variable in class com.pivotal.rabbitmq.schema.SchemaManager
 

T

terminate - Static variable in class com.pivotal.rabbitmq.stream.IllegalEventHandler
 
terminate() - Method in class com.pivotal.rabbitmq.stream.UnableBuildEventHandling
 
terminate() - Method in class com.pivotal.rabbitmq.stream.UnserializableEventHandling
 
terminateWhen(Class<? extends Throwable>...) - Static method in class com.pivotal.rabbitmq.ReactiveRabbit
 
terminateWhen(Class<? extends Throwable>...) - Method in class com.pivotal.rabbitmq.TransactionRollbackStrategy
 
then() - Method in class com.pivotal.rabbitmq.stream.BaseStreamConfigurer
 
then() - Method in class com.pivotal.rabbitmq.topology.Exchange
 
then() - Method in class com.pivotal.rabbitmq.topology.Queue
 
timestamp(Function<T, Date>) - Method in class com.pivotal.rabbitmq.stream.EventAttributes
 
timestamp(Date) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
TLSv1_1 - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
TLSv1_2 - Static variable in class com.pivotal.rabbitmq.RabbitSslProperties
 
toEventType(Delivery) - Method in class com.pivotal.rabbitmq.stream.AbstractConsumerStream
 
toExchange(String) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
toExchange(String) - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
toParsingForm(Schema) - Static method in class com.pivotal.rabbitmq.schema.SchemaManager
 
topic - Static variable in class com.pivotal.rabbitmq.topology.ExchangeType
 
Topology - Interface in com.pivotal.rabbitmq.topology
 
topologyAvailabilityErrors() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
TopologyBuilder - Class in com.pivotal.rabbitmq.topology
 
TopologyBuilder(boolean) - Constructor for class com.pivotal.rabbitmq.topology.TopologyBuilder
 
TopologyBuilder() - Constructor for class com.pivotal.rabbitmq.topology.TopologyBuilder
 
TopologyConfigurer - Class in com.pivotal.rabbitmq.topology
 
TopologyConfigurer() - Constructor for class com.pivotal.rabbitmq.topology.TopologyConfigurer
 
TopologyManager - Interface in com.pivotal.rabbitmq.topology
 
TopologyManagerImpl(Supplier<RabbitEndpoint>) - Constructor for class com.pivotal.rabbitmq.ReactiveRabbitBuilder.TopologyManagerImpl
 
toString() - Method in class com.pivotal.rabbitmq.RabbitEndpoint
 
toString() - Method in class com.pivotal.rabbitmq.RabbitProperties
 
toString() - Method in class com.pivotal.rabbitmq.stream.Transactional.Identifier
 
toString() - Method in class com.pivotal.rabbitmq.stream.Version
 
trackReturnedMessages() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
Transaction<T> - Interface in com.pivotal.rabbitmq.stream
 
Transactional<T> - Class in com.pivotal.rabbitmq.stream
 
Transactional(Transactional.Identifier, T, Consumer<Transactional.Identifier>, Consumer<Transactional.Identifier>, Consumer<Transactional.Identifier>) - Constructor for class com.pivotal.rabbitmq.stream.Transactional
For root transaction
Transactional.Identifier - Class in com.pivotal.rabbitmq.stream
 
TransactionalConsumerStream<T> - Class in com.pivotal.rabbitmq.stream
 
TransactionalConsumerStream(Supplier<RabbitEndpoint>, Mono<Topology>, Class<T>, SchemaManager, String) - Constructor for class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
TransactionalProducerStream<T> - Class in com.pivotal.rabbitmq.stream
 
TransactionalProducerStream(Supplier<RabbitEndpoint>, Mono<Topology>, Class<T>, SchemaManager) - Constructor for class com.pivotal.rabbitmq.stream.TransactionalProducerStream
 
TransactionManager<T,R extends Transaction<T>> - Class in com.pivotal.rabbitmq.stream
 
TransactionManager(String) - Constructor for class com.pivotal.rabbitmq.stream.TransactionManager
 
TransactionRollbackStrategy<T> - Class in com.pivotal.rabbitmq
 
TransactionRollbackStrategy() - Constructor for class com.pivotal.rabbitmq.TransactionRollbackStrategy
 
type(ExchangeType) - Method in class com.pivotal.rabbitmq.topology.Exchange
 

U

UnableBuildEventHandling<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
Unable to build an event due to one of the contributor functions threw an exception.
UnableBuildEventHandling.Strategy - Enum in com.pivotal.rabbitmq.stream
 
UnroutableEventHandling<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
UnroutableEventHandling.Strategy - Enum in com.pivotal.rabbitmq.stream
 
unroutableEventStrategy - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
UnserializableEventHandling<T,P extends com.pivotal.rabbitmq.stream.BaseStream<T>> - Class in com.pivotal.rabbitmq.stream
 
UnserializableEventHandling.Strategy - Enum in com.pivotal.rabbitmq.stream
 
unserializableEventStrategy - Variable in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
useAlternateExchange() - Method in class com.pivotal.rabbitmq.stream.UnroutableEventHandling
 
useExchangeSelector(Function<T, String>) - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 

V

valueOf(String) - Static method in enum com.pivotal.rabbitmq.schema.SchemaManager.SchemaRegistryStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.stream.RedeliveryReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.stream.UnableBuildEventHandling.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.stream.UnroutableEventHandling.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.stream.UnserializableEventHandling.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class com.pivotal.rabbitmq.topology.ExchangeType
 
valueOf(String) - Static method in enum com.pivotal.rabbitmq.topology.MaxLengthStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.topology.Queue.MaxLengthStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.pivotal.rabbitmq.topology.QueueType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.pivotal.rabbitmq.schema.SchemaManager.SchemaRegistryStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.stream.RedeliveryReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.stream.UnableBuildEventHandling.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.stream.UnroutableEventHandling.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.stream.UnserializableEventHandling.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.topology.MaxLengthStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.topology.Queue.MaxLengthStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.pivotal.rabbitmq.topology.QueueType
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in interface com.pivotal.rabbitmq.stream.Transaction
 
version() - Method in class com.pivotal.rabbitmq.stream.Transactional
 
Version - Class in com.pivotal.rabbitmq.stream
 
Version(long) - Constructor for class com.pivotal.rabbitmq.stream.Version
 
version() - Method in interface com.pivotal.rabbitmq.stream.Versioned
 
Versioned - Interface in com.pivotal.rabbitmq.stream
 
VND_CONTENT_TYPE_PREFIX - Static variable in class com.pivotal.rabbitmq.schema.SchemaManager
 

W

whenNackByBroker() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
whenReceiveIllegalEvents() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
whenReceiveIllegalMessages() - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
whenUnroutable() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
whenUnserializable() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withAlternateExchange(String) - Method in class com.pivotal.rabbitmq.topology.Exchange
 
withAttributes() - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withAttributes(boolean) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withAvroCodec() - Method in class com.pivotal.rabbitmq.stream.ConsumerStream
 
withAvroCodec() - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
withCodec(Codec) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withCodec(Codec) - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
withDeadLetterExchange(String) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withDeadLetterExchange(String, String) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withDeadLetterQueue() - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
withDefaultEndpointName(String) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
withDeliveryLimit(int) - Method in interface com.pivotal.rabbitmq.topology.QuorumQueue
https://www.rabbitmq.com/quorum-queues.html#poison-message-handling
withInstanceId(String) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
withMaxInFight(Integer) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withMaxInMemoryBytes(int) - Method in interface com.pivotal.rabbitmq.topology.QuorumQueue
Sets a limit as the total size of message bodies (payloads), in bytes.
withMaxInMemoryLength(int) - Method in interface com.pivotal.rabbitmq.topology.QuorumQueue
Sets a limit as a number of messages.
withMaxLength(int) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withMaxLength(int, Queue.MaxLengthStrategy) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withMaxLengthBytes(int) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withMaxLengthBytes(int, Queue.MaxLengthStrategy) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withMaxQueueLength(Integer) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
withMaxQueueLength(Integer) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
withMessageTTL(Duration) - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
withName(String) - Method in class com.pivotal.rabbitmq.stream.AbstractProducerStream
 
withoutReplication() - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
withPartitionKeyInCorrelationId() - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
withPartitionKeyInHeader(String) - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
withPartitionKeyInMessageId() - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
withPartitionKeyInRoutingKey() - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
withPartitionKeyInTimestamp() - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
withPartitions(Integer) - Method in class com.pivotal.rabbitmq.topologies.BroadcastTopology.SubscriberProperties
 
withPartitions(Integer) - Method in class com.pivotal.rabbitmq.topologies.MulticastTopology.SubscriberProperties
 
withPartitions(int) - Method in class com.pivotal.rabbitmq.topology.Queue
 
withPrefetch(int) - Method in class com.pivotal.rabbitmq.stream.TransactionalConsumerStream
 
withReplicas(int, boolean) - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
withReplicas(int) - Method in interface com.pivotal.rabbitmq.topology.ClassicQueue
 
withReplicas(int) - Method in interface com.pivotal.rabbitmq.topology.QuorumQueue
https://www.rabbitmq.com/quorum-queues.html#replication-factor
withRoutingKey(String) - Method in interface com.pivotal.rabbitmq.stream.EventMessageBuilder
 
withRoutingKey(Function<T, String>) - Method in class com.pivotal.rabbitmq.stream.RoutingStrategies
 
withSchemaRegistry(SchemaProperties) - Method in class com.pivotal.rabbitmq.ReactiveRabbitBuilder
 
withSingleConsumerPerPartition(boolean) - Method in class com.pivotal.rabbitmq.topology.PartitionSpecification
 
A B C D E F G H I J L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2021. All rights reserved.