Package | Description |
---|---|
org.springframework.amqp.rabbit.connection |
Provides classes related to connections.
|
org.springframework.amqp.rabbit.core |
Provides core classes for Spring Rabbit.
|
org.springframework.amqp.rabbit.core.support |
Provides core support classes for Spring Rabbit.
|
org.springframework.amqp.rabbit.listener |
Provides classes for message listener containers.
|
org.springframework.amqp.rabbit.transaction |
Provides classes supporting transactions in Spring Rabbit.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractConnectionFactory |
class |
AbstractRoutingConnectionFactory
Abstract
ConnectionFactory implementation that routes AbstractRoutingConnectionFactory.createConnection()
calls to one of various target ConnectionFactories based on a lookup key. |
class |
CachingConnectionFactory
A
ConnectionFactory implementation that (when the cache mode is CachingConnectionFactory.CacheMode.CHANNEL (default)
returns the same Connection from all CachingConnectionFactory.createConnection()
calls, and ignores calls to Connection.close() and caches
Channel . |
class |
SimpleRoutingConnectionFactory
An
AbstractRoutingConnectionFactory implementation which gets a lookupKey
for current ConnectionFactory from thread-bound resource by key of the instance of
this ConnectionFactory . |
Modifier and Type | Method and Description |
---|---|
protected ConnectionFactory |
AbstractRoutingConnectionFactory.determineTargetConnectionFactory()
Retrieve the current target
ConnectionFactory . |
ConnectionFactory |
RabbitAccessor.getConnectionFactory() |
protected ConnectionFactory |
AbstractRoutingConnectionFactory.getTargetConnectionFactory(Object key)
Returns the
ConnectionFactory bound to given lookup key, null if one does not exist |
protected ConnectionFactory |
AbstractRoutingConnectionFactory.removeTargetConnectionFactory(Object key)
Removes the
ConnectionFactory associated with the given lookup key and returns it. |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractRoutingConnectionFactory.addTargetConnectionFactory(Object key,
ConnectionFactory connectionFactory)
Adds the given
ConnectionFactory and associates it with the given lookup key |
static void |
ConnectionFactoryUtils.bindResourceToTransaction(RabbitResourceHolder resourceHolder,
ConnectionFactory connectionFactory,
boolean synched) |
static com.rabbitmq.client.Channel |
ConsumerChannelRegistry.getConsumerChannel(ConnectionFactory connectionFactory)
See registerConsumerChannel.
|
static RabbitResourceHolder |
ConnectionFactoryUtils.getTransactionalResourceHolder(ConnectionFactory connectionFactory,
boolean synchedLocalTransactionAllowed)
Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.
|
static boolean |
ConnectionFactoryUtils.isChannelTransactional(com.rabbitmq.client.Channel channel,
ConnectionFactory connectionFactory)
Determine whether the given RabbitMQ Channel is transactional, that is, bound to the current thread by Spring's
transaction facilities.
|
static void |
ConsumerChannelRegistry.registerConsumerChannel(com.rabbitmq.client.Channel channel,
ConnectionFactory connectionFactory)
If a listener container is configured to use a RabbitTransactionManager, the
consumer's channel is registered here so that it is used as the bound resource
when the transaction actually starts.
|
static void |
ConnectionFactoryUtils.registerDeliveryTag(ConnectionFactory connectionFactory,
com.rabbitmq.client.Channel channel,
Long tag) |
void |
RabbitAccessor.setConnectionFactory(ConnectionFactory connectionFactory)
Set the ConnectionFactory to use for obtaining RabbitMQ
Connections . |
void |
AbstractRoutingConnectionFactory.setDefaultTargetConnectionFactory(ConnectionFactory defaultTargetConnectionFactory)
Specify the default target
ConnectionFactory , if any. |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRoutingConnectionFactory.setTargetConnectionFactories(Map<Object,ConnectionFactory> targetConnectionFactories)
Specify the map of target ConnectionFactories, with the lookup key as key.
|
Constructor and Description |
---|
RabbitAdmin(ConnectionFactory connectionFactory) |
RabbitTemplate(ConnectionFactory connectionFactory)
Create a rabbit template with default strategies and settings.
|
Modifier and Type | Method and Description |
---|---|
ConnectionFactory |
RabbitGatewaySupport.getConnectionFactory() |
Modifier and Type | Method and Description |
---|---|
protected RabbitTemplate |
RabbitGatewaySupport.createRabbitTemplate(ConnectionFactory connectionFactory)
Create a RabbitTemplate for the given ConnectionFactory.
|
void |
RabbitGatewaySupport.setConnectionFactory(ConnectionFactory connectionFactory)
Set the Rabbit connection factory to be used by the gateway.
|
Constructor and Description |
---|
BlockingQueueConsumer(ConnectionFactory connectionFactory,
MessagePropertiesConverter messagePropertiesConverter,
ActiveObjectCounter<BlockingQueueConsumer> activeObjectCounter,
AcknowledgeMode acknowledgeMode,
boolean transactional,
int prefetchCount,
boolean defaultRequeueRejected,
Map<String,Object> consumerArgs,
boolean exclusive,
String... queues)
Create a consumer.
|
BlockingQueueConsumer(ConnectionFactory connectionFactory,
MessagePropertiesConverter messagePropertiesConverter,
ActiveObjectCounter<BlockingQueueConsumer> activeObjectCounter,
AcknowledgeMode acknowledgeMode,
boolean transactional,
int prefetchCount,
boolean defaultRequeueRejected,
Map<String,Object> consumerArgs,
String... queues)
Create a consumer.
|
BlockingQueueConsumer(ConnectionFactory connectionFactory,
MessagePropertiesConverter messagePropertiesConverter,
ActiveObjectCounter<BlockingQueueConsumer> activeObjectCounter,
AcknowledgeMode acknowledgeMode,
boolean transactional,
int prefetchCount,
boolean defaultRequeueRejected,
String... queues)
Create a consumer.
|
BlockingQueueConsumer(ConnectionFactory connectionFactory,
MessagePropertiesConverter messagePropertiesConverter,
ActiveObjectCounter<BlockingQueueConsumer> activeObjectCounter,
AcknowledgeMode acknowledgeMode,
boolean transactional,
int prefetchCount,
String... queues)
Create a consumer.
|
SimpleMessageListenerContainer(ConnectionFactory connectionFactory)
Create a listener container from the connection factory (mandatory).
|
Modifier and Type | Method and Description |
---|---|
ConnectionFactory |
RabbitTransactionManager.getConnectionFactory() |
Modifier and Type | Method and Description |
---|---|
void |
RabbitTransactionManager.setConnectionFactory(ConnectionFactory connectionFactory) |
Constructor and Description |
---|
RabbitTransactionManager(ConnectionFactory connectionFactory)
Create a new RabbitTransactionManager, given a ConnectionFactory.
|
Copyright © 2016. All rights reserved.