Uses of Interface
org.springframework.amqp.rabbit.connection.ConnectionFactory
Package
Description
Provides top-level classes for Spring Rabbit.
Provides classes supporting the Rabbit XML namespace.
Provides classes related to connections.
Provides core classes for Spring Rabbit.
Provides classes for message listener containers.
Classes for testing Spring AMQP applications.
Provides classes supporting transactions in Spring Rabbit.
-
Uses of ConnectionFactory in org.springframework.amqp.rabbit
ModifierConstructorDescriptionAsyncRabbitTemplate
(ConnectionFactory connectionFactory, String exchange, String routingKey) Construct an instance using the provided arguments.AsyncRabbitTemplate
(ConnectionFactory connectionFactory, String exchange, String routingKey, String replyQueue) Construct an instance using the provided arguments.AsyncRabbitTemplate
(ConnectionFactory connectionFactory, String exchange, String routingKey, String replyQueue, String replyAddress) Construct an instance using the provided arguments. -
Uses of ConnectionFactory in org.springframework.amqp.rabbit.config
Modifier and TypeMethodDescriptionvoid
AbstractRabbitListenerContainerFactory.setConnectionFactory
(ConnectionFactory connectionFactory) void
ListenerContainerFactoryBean.setConnectionFactory
(ConnectionFactory connectionFactory) -
Uses of ConnectionFactory in org.springframework.amqp.rabbit.connection
Modifier and TypeClassDescriptionclass
class
AbstractConnectionFactory
implementation that routesAbstractRoutingConnectionFactory.createConnection()
calls to one of various target ConnectionFactories based on a lookup key.class
AConnectionFactory
implementation that (when the cache mode isCachingConnectionFactory.CacheMode.CHANNEL
(default) returns the same Connection from allCachingConnectionFactory.createConnection()
calls, and ignores calls toConnection.close()
and cachesChannel
.class
ARoutingConnectionFactory
that determines the node on which a queue is located and returns a factory that connects directly to that node.class
A very simple connection factory that caches channels using Apache Pool2GenericObjectPool
s (one for transactional and one for non-transactional channels).class
AnAbstractRoutingConnectionFactory
implementation which gets alookupKey
for currentConnectionFactory
from thread-bound resource by key of the instance of thisConnectionFactory
.class
A very simple connection factory that caches a channel per thread.Modifier and TypeMethodDescriptionprotected ConnectionFactory
LocalizedQueueConnectionFactory.createConnectionFactory
(String address, String node) Create a dedicated connection factory for the address.protected ConnectionFactory
AbstractRoutingConnectionFactory.determineTargetConnectionFactory()
Retrieve the current targetConnectionFactory
.RabbitAccessor.getConnectionFactory()
AbstractConnectionFactory.getPublisherConnectionFactory()
default ConnectionFactory
ConnectionFactory.getPublisherConnectionFactory()
Return a separate connection factory for publishers (if implemented).AbstractRoutingConnectionFactory.getTargetConnectionFactory
(Object key) LocalizedQueueConnectionFactory.getTargetConnectionFactory
(Object key) RoutingConnectionFactory.getTargetConnectionFactory
(Object key) Returns theConnectionFactory
bound to given lookup key, or null if one does not exist.Locate or create a factory.default ConnectionFactory
NodeLocator.locate
(String[] adminUris, Map<String, String> nodeToAddress, String vhost, String username, String password, String queue, FactoryFinder factoryFunction) Return a connection factory for the leader node for the queue.protected ConnectionFactory
AbstractRoutingConnectionFactory.removeTargetConnectionFactory
(Object key) Removes theConnectionFactory
associated with the given lookup key and returns it.Modifier and TypeMethodDescriptionprotected void
AbstractRoutingConnectionFactory.addTargetConnectionFactory
(Object key, ConnectionFactory connectionFactory) Adds the givenConnectionFactory
and associates it with the given lookup key.static RabbitResourceHolder
ConnectionFactoryUtils.bindResourceToTransaction
(RabbitResourceHolder resourceHolder, ConnectionFactory connectionFactory, boolean synched) static Connection
ConnectionFactoryUtils.createConnection
(ConnectionFactory connectionFactory, boolean publisherConnectionIfPossible) Create a connection with this connection factory and/or its publisher factory.static com.rabbitmq.client.Channel
ConsumerChannelRegistry.getConsumerChannel
(ConnectionFactory connectionFactory) See registerConsumerChannel.static int
RabbitUtils.getMaxFrame
(ConnectionFactory connectionFactory) Return the negotiated frame_max.static RabbitResourceHolder
ConnectionFactoryUtils.getTransactionalResourceHolder
(ConnectionFactory connectionFactory, boolean synchedLocalTransactionAllowed) Obtain a RabbitMQ Channel that is synchronized with the current transaction, if any.static RabbitResourceHolder
ConnectionFactoryUtils.getTransactionalResourceHolder
(ConnectionFactory connectionFactory, boolean synchedLocalTransactionAllowed, boolean publisherConnectionIfPossible) 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.ConnectionNameStrategy.obtainNewConnectionName
(ConnectionFactory connectionFactory) SimplePropertyValueConnectionNameStrategy.obtainNewConnectionName
(ConnectionFactory connectionFactory) 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 RabbitMQConnections
.void
AbstractRoutingConnectionFactory.setDefaultTargetConnectionFactory
(ConnectionFactory defaultTargetConnectionFactory) Specify the default targetConnectionFactory
, if any.Modifier and TypeMethodDescriptionvoid
AbstractRoutingConnectionFactory.setTargetConnectionFactories
(Map<Object, ConnectionFactory> targetConnectionFactories) Specify the map of target ConnectionFactories, with the lookup key as key.ModifierConstructorDescriptionConnectionFactoryContextWrapper
(ConnectionFactory connectionFactory) LocalizedQueueConnectionFactory
(ConnectionFactory defaultConnectionFactory, String[] addresses, String[] adminUris, String[] nodes, String vhost, String username, String password, boolean useSSL, String keyStore, String trustStore, String keyStorePassPhrase, String trustStorePassPhrase) LocalizedQueueConnectionFactory
(ConnectionFactory defaultConnectionFactory, String[] addresses, String[] adminUris, String[] nodes, String vhost, String username, String password, boolean useSSL, Resource sslPropertiesLocation) LocalizedQueueConnectionFactory
(ConnectionFactory defaultConnectionFactory, Map<String, String> nodeToAddress, String[] adminUris, String vhost, String username, String password, boolean useSSL, String keyStore, String trustStore, String keyStorePassPhrase, String trustStorePassPhrase) LocalizedQueueConnectionFactory
(ConnectionFactory defaultConnectionFactory, Map<String, String> nodeToAddress, String[] adminUris, String vhost, String username, String password, boolean useSSL, Resource sslPropertiesLocation) -
Uses of ConnectionFactory in org.springframework.amqp.rabbit.core
Modifier and TypeMethodDescriptionfinal ConnectionFactory
RabbitGatewaySupport.getConnectionFactory()
RabbitOperations.getConnectionFactory()
Return the connection factory for this operations.Modifier and TypeMethodDescriptionprotected RabbitTemplate
RabbitGatewaySupport.createRabbitTemplate
(ConnectionFactory connectionFactory) Create a RabbitTemplate for the given ConnectionFactory.final void
RabbitGatewaySupport.setConnectionFactory
(ConnectionFactory connectionFactory) Set the Rabbit connection factory to be used by the gateway.final void
RabbitTemplate.setConnectionFactory
(ConnectionFactory connectionFactory) ModifierConstructorDescriptionBatchingRabbitTemplate
(ConnectionFactory connectionFactory, BatchingStrategy batchingStrategy, TaskScheduler scheduler) Create an instance with the supplied parameters.BrokerEventListener
(ConnectionFactory connectionFactory, String... eventKeys) Construct an instance using the supplied connection factory and event keys.RabbitAdmin
(ConnectionFactory connectionFactory) Construct an instance using the providedConnectionFactory
.RabbitTemplate
(ConnectionFactory connectionFactory) Create a rabbit template with default strategies and settings. -
Uses of ConnectionFactory in org.springframework.amqp.rabbit.listener
ModifierConstructorDescriptionBlockingQueueConsumer
(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, boolean defaultRequeueRejected, Map<String, Object> consumerArgs, boolean noLocal, 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, 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, String... queues) Create a consumer.DirectMessageListenerContainer
(ConnectionFactory connectionFactory) Create an instance with the provided connection factory.DirectReplyToMessageListenerContainer
(ConnectionFactory connectionFactory) SimpleMessageListenerContainer
(ConnectionFactory connectionFactory) Create a listener container from the connection factory (mandatory). -
Uses of ConnectionFactory in org.springframework.amqp.rabbit.test
-
Uses of ConnectionFactory in org.springframework.amqp.rabbit.transaction
Modifier and TypeMethodDescriptionvoid
RabbitTransactionManager.setConnectionFactory
(ConnectionFactory connectionFactory) ModifierConstructorDescriptionRabbitTransactionManager
(ConnectionFactory connectionFactory) Create a new RabbitTransactionManager, given a ConnectionFactory.