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

A

AbstractJmsListeningContainer - Class in org.springframework.jms.listener
Common base class for all containers which need to implement listening based on a JMS Connection (either shared or freshly obtained for each attempt).
AbstractJmsListeningContainer() - Constructor for class org.springframework.jms.listener.AbstractJmsListeningContainer
 
AbstractJmsListeningContainer.SharedConnectionNotInitializedException - Exception in org.springframework.jms.listener
Exception that indicates that the initial setup of this container's shared JMS Connection failed.
AbstractMessageListenerContainer - Class in org.springframework.jms.listener
Abstract base class for message listener containers.
AbstractMessageListenerContainer() - Constructor for class org.springframework.jms.listener.AbstractMessageListenerContainer
 
AbstractPollingMessageListenerContainer - Class in org.springframework.jms.listener
Base class for listener container implementations which are based on polling.
AbstractPollingMessageListenerContainer() - Constructor for class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
 
addConnection(Connection) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
addDelegate(ExceptionListener) - Method in class org.springframework.jms.connection.ChainedExceptionListener
Add an ExceptionListener to the chained delegate list.
addSession(Session) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
addSession(Session, Connection) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
afterPropertiesSet() - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.jms.connection.JmsTransactionManager
Make sure the ConnectionFactory has been set.
afterPropertiesSet() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Make sure a Connection or ConnectionFactory has been set.
afterPropertiesSet() - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
 
afterPropertiesSet() - Method in class org.springframework.jms.core.support.JmsGatewaySupport
 
afterPropertiesSet() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
afterPropertiesSet() - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
 
afterPropertiesSet() - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
 
afterPropertiesSet() - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
 
afterPropertiesSet() - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
 
afterPropertiesSet() - Method in class org.springframework.jms.support.JmsAccessor
 
applyAcknowledgeMode(BeanWrapper, int) - Method in class org.springframework.jms.listener.endpoint.DefaultJmsActivationSpecFactory
This implementation maps SESSION_TRANSACTED onto an ActivationSpec property named "useRAManagedTransaction", if available (following ActiveMQ's naming conventions).
applyAcknowledgeMode(BeanWrapper, int) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Apply the specified acknowledge mode to the ActivationSpec object.

B

BeanFactoryDestinationResolver - Class in org.springframework.jms.support.destination
DestinationResolver implementation based on a Spring BeanFactory.
BeanFactoryDestinationResolver() - Constructor for class org.springframework.jms.support.destination.BeanFactoryDestinationResolver
Create a new instance of the BeanFactoryDestinationResolver class.
BeanFactoryDestinationResolver(BeanFactory) - Constructor for class org.springframework.jms.support.destination.BeanFactoryDestinationResolver
Create a new instance of the BeanFactoryDestinationResolver class.
browse(BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse messages in the default JMS queue.
browse(Queue, BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse messages in a JMS queue.
browse(String, BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse messages in a JMS queue.
browse(BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
browse(Queue, BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
browse(String, BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
BrowserCallback<T> - Interface in org.springframework.jms.core
Callback for browsing the messages in a JMS queue.
browseSelected(String, BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse selected messages in a JMS queue.
browseSelected(Queue, String, BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse selected messages in a JMS queue.
browseSelected(String, String, BrowserCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Browse selected messages in a JMS queue.
browseSelected(String, BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
browseSelected(Queue, String, BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
browseSelected(String, String, BrowserCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
buildExceptionMessage(JMSException) - Static method in class org.springframework.jms.support.JmsUtils
Build a descriptive exception message for the given JMSException, incorporating a linked exception's message if appropriate.
buildListenerArguments(Object) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Build an array of arguments to be passed into the target listener method.
buildMessage(Session, Object) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Build a JMS message to be sent as response based on the given result object.

C

CACHE_AUTO - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Constant that indicates automatic choice of an appropriate caching level (depending on the transaction management strategy).
CACHE_CONNECTION - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Constant that indicates to cache a shared JMS Connection for each listener thread.
CACHE_CONSUMER - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Constant that indicates to cache a shared JMS Connection, a JMS Session, and a JMS MessageConsumer for each listener thread.
CACHE_NONE - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Constant that indicates to cache no JMS resources at all.
CACHE_SESSION - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Constant that indicates to cache a shared JMS Connection and a JMS Session for each listener thread.
CachingConnectionFactory - Class in org.springframework.jms.connection
SingleConnectionFactory subclass that adds Session caching as well MessageProducer caching.
CachingConnectionFactory() - Constructor for class org.springframework.jms.connection.CachingConnectionFactory
Create a new CachingConnectionFactory for bean-style usage.
CachingConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.jms.connection.CachingConnectionFactory
Create a new CachingConnectionFactory for the given target ConnectionFactory.
CachingDestinationResolver - Interface in org.springframework.jms.support.destination
Extension of the DestinationResolver interface, exposing methods for clearing the cache.
ChainedExceptionListener - Class in org.springframework.jms.connection
Implementation of the JMS ExceptionListener interface that supports chaining, allowing the addition of multiple ExceptionListener instances in order.
ChainedExceptionListener() - Constructor for class org.springframework.jms.connection.ChainedExceptionListener
 
checkMessageListener(Object) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Check the given message listener, throwing an exception if it does not correspond to a supported listener type.
clearCache() - Method in interface org.springframework.jms.support.destination.CachingDestinationResolver
Clear the entire destination cache.
clearCache() - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
 
closeAll() - Method in class org.springframework.jms.connection.JmsResourceHolder
 
closeConnection(Connection) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Close the given Connection.
closeConnection(Connection) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS Connection and ignore any thrown exception.
closeConnection(Connection, boolean) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS Connection and ignore any thrown exception.
closeMessageConsumer(MessageConsumer) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS MessageConsumer and ignore any thrown exception.
closeMessageProducer(MessageProducer) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS MessageProducer and ignore any thrown exception.
closeQueueBrowser(QueueBrowser) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS QueueBrowser and ignore any thrown exception.
closeQueueRequestor(QueueRequestor) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS QueueRequestor and ignore any thrown exception.
closeSession(Session) - Static method in class org.springframework.jms.support.JmsUtils
Close the given JMS Session and ignore any thrown exception.
commitAll() - Method in class org.springframework.jms.connection.JmsResourceHolder
 
commitIfNecessary(Session, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Perform a commit or message acknowledgement, as appropriate.
commitIfNecessary(Session) - Static method in class org.springframework.jms.support.JmsUtils
Commit the Session if not within a JTA transaction.
ConnectionFactoryUtils - Class in org.springframework.jms.connection
Helper class for managing a JMS ConnectionFactory, in particular for obtaining transactional JMS resources for a given ConnectionFactory.
ConnectionFactoryUtils() - Constructor for class org.springframework.jms.connection.ConnectionFactoryUtils
 
ConnectionFactoryUtils.ResourceFactory - Interface in org.springframework.jms.connection
Callback interface for resource creation.
containsSession(Session) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
convertAndSend(Object) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the default destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(Destination, Object) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the specified destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(String, Object) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the specified destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(Object, MessagePostProcessor) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the default destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(Destination, Object, MessagePostProcessor) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the specified destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(String, Object, MessagePostProcessor) - Method in interface org.springframework.jms.core.JmsOperations
Send the given object to the specified destination, converting the object to a JMS message with a configured MessageConverter.
convertAndSend(Object) - Method in class org.springframework.jms.core.JmsTemplate
 
convertAndSend(Destination, Object) - Method in class org.springframework.jms.core.JmsTemplate
 
convertAndSend(String, Object) - Method in class org.springframework.jms.core.JmsTemplate
 
convertAndSend(Object, MessagePostProcessor) - Method in class org.springframework.jms.core.JmsTemplate
 
convertAndSend(Destination, Object, MessagePostProcessor) - Method in class org.springframework.jms.core.JmsTemplate
 
convertAndSend(String, Object, MessagePostProcessor) - Method in class org.springframework.jms.core.JmsTemplate
 
convertFromBytesMessage(BytesMessage, JavaType) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Convert a BytesMessage to a Java Object with the specified type.
convertFromBytesMessage(BytesMessage, JavaType) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Convert a BytesMessage to a Java Object with the specified type.
convertFromMessage(Message, JavaType) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Template method that allows for custom message mapping.
convertFromMessage(Message, JavaType) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Template method that allows for custom message mapping.
convertFromTextMessage(TextMessage, JavaType) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Convert a TextMessage to a Java Object with the specified type.
convertFromTextMessage(TextMessage, JavaType) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Convert a TextMessage to a Java Object with the specified type.
convertJmsAccessException(JMSException) - Method in class org.springframework.jms.support.JmsAccessor
Convert the specified checked JMSException to a Spring runtime JmsException equivalent.
convertJmsAccessException(JMSException) - Static method in class org.springframework.jms.support.JmsUtils
Convert the specified checked JMSException to a Spring runtime JmsException equivalent.
convertJmsInvokerAccessException(JMSException) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Convert the given JMS invoker access exception to an appropriate Spring RemoteAccessException.
createActivationSpec(ResourceAdapter, JmsActivationSpecConfig) - Method in interface org.springframework.jms.listener.endpoint.JmsActivationSpecFactory
Create a JCA 1.5 ActivationSpec object based on the given JmsActivationSpecConfig object.
createActivationSpec(ResourceAdapter, JmsActivationSpecConfig) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
 
createBrowser(Session, Queue, String) - Method in class org.springframework.jms.core.JmsTemplate
Create a JMS MessageProducer for the given Session and Destination, configuring it to disable message ids and/or timestamps (if necessary).
createConnection() - Method in interface org.springframework.jms.connection.ConnectionFactoryUtils.ResourceFactory
Create a new JMS Connection for registration with a JmsResourceHolder.
createConnection() - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createConnection(String, String) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createConnection() - Method in class org.springframework.jms.connection.JmsTransactionManager
Create a JMS Connection via this template's ConnectionFactory.
createConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createConnection(String, String) - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createConnection() - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createConnection(String, String) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createConnection() - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Determine whether there are currently thread-bound credentials, using them if available, falling back to the statically specified username and password (i.e.
createConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Delegate the call straight to the target ConnectionFactory.
createConnection() - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Create a new JMS Connection for this JMS invoker.
createConnection() - Method in class org.springframework.jms.support.JmsAccessor
Create a JMS Connection via this template's ConnectionFactory.
createConsumer(Session, Destination, String) - Method in class org.springframework.jms.core.JmsTemplate
Create a JMS MessageConsumer for the given Session and Destination.
createConsumer(Session, Destination) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Create a JMS MessageConsumer for the given Session and Destination.
createConsumer(Session, Destination) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Create a JMS MessageConsumer for the given Session and Destination.
createDefaultTaskExecutor() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Create a default TaskExecutor.
createEndpointInternal() - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointFactory
Creates a concrete JMS message endpoint, internal to this factory.
createJmsTemplate(ConnectionFactory) - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Create a JmsTemplate for the given ConnectionFactory.
createListenerConsumer(Session) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Create a MessageConsumer for the given JMS Session, registering a MessageListener for the specified listener.
createListenerConsumer(Session) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Create a MessageConsumer for the given JMS Session, registering a MessageListener for the specified listener.
createMessage(Session) - Method in interface org.springframework.jms.core.MessageCreator
Create a Message to be sent.
createMessageForByteArray(byte[], Session) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Create a JMS BytesMessage for the given byte array.
createMessageForMap(Map<?, ?>, Session) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Create a JMS MapMessage for the given Map.
createMessageForSerializable(Serializable, Session) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Create a JMS ObjectMessage for the given Serializable object.
createMessageForString(String, Session) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Create a JMS TextMessage for the given String.
createProducer(Session, Destination) - Method in class org.springframework.jms.core.JmsTemplate
Create a JMS MessageProducer for the given Session and Destination, configuring it to disable message ids and/or timestamps (if necessary).
createQueueConnection() - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createQueueConnection(String, String) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createQueueConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createQueueConnection(String, String) - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createQueueConnection() - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createQueueConnection(String, String) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createQueueConnection() - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Determine whether there are currently thread-bound credentials, using them if available, falling back to the statically specified username and password (i.e.
createQueueConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Delegate the call straight to the target QueueConnectionFactory.
createRemoteInvocation(MethodInvocation) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Create a new RemoteInvocation object for the given AOP method invocation.
createRequestMessage(Session, RemoteInvocation) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Create the invoker request message.
createResponseMessage(Message, Session, RemoteInvocationResult) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Create the invocation result response message.
createSession(Connection) - Method in interface org.springframework.jms.connection.ConnectionFactoryUtils.ResourceFactory
Create a new JMS Session for registration with a JmsResourceHolder.
createSession(Connection) - Method in class org.springframework.jms.connection.JmsTransactionManager
Create a JMS Session for the given Connection.
createSession(Connection, Integer) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Create a default Session for this ConnectionFactory, adapting to JMS 1.0.2 style queue/topic mode if necessary.
createSession(Connection) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Create a new JMS Session for this JMS invoker.
createSession(Connection) - Method in class org.springframework.jms.support.JmsAccessor
Create a JMS Session for the given Connection.
createSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Create a shared Connection for this container.
createTopicConnection() - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createTopicConnection(String, String) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
createTopicConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createTopicConnection(String, String) - Method in class org.springframework.jms.connection.SingleConnectionFactory
 
createTopicConnection() - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createTopicConnection(String, String) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
 
createTopicConnection() - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Determine whether there are currently thread-bound credentials, using them if available, falling back to the statically specified username and password (i.e.
createTopicConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Delegate the call straight to the target TopicConnectionFactory.

D

DEFAULT_ENCODING - Static variable in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
The default encoding used for writing to text messages: UTF-8.
DEFAULT_ENCODING - Static variable in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
The default encoding used for writing to text messages: UTF-8.
DEFAULT_RECEIVE_TIMEOUT - Static variable in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
The default receive timeout: 1000 ms = 1 second.
DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
The default recovery interval: 5000 ms = 5 seconds.
DEFAULT_THREAD_NAME_PREFIX - Static variable in class org.springframework.jms.listener.DefaultMessageListenerContainer
Default thread name prefix: "DefaultMessageListenerContainer-".
DefaultJmsActivationSpecFactory - Class in org.springframework.jms.listener.endpoint
Default implementation of the JmsActivationSpecFactory interface.
DefaultJmsActivationSpecFactory() - Constructor for class org.springframework.jms.listener.endpoint.DefaultJmsActivationSpecFactory
 
DefaultMessageListenerContainer - Class in org.springframework.jms.listener
Message listener container variant that uses plain JMS client APIs, specifically a loop of MessageConsumer.receive() calls that also allow for transactional reception of messages (registering them with XA transactions).
DefaultMessageListenerContainer() - Constructor for class org.springframework.jms.listener.DefaultMessageListenerContainer
 
DelegatingConnectionFactory - Class in org.springframework.jms.connection
ConnectionFactory implementation that delegates all calls to a given target ConnectionFactory, adapting specific create(Queue/Topic)Connection calls to the target ConnectionFactory if necessary (e.g.
DelegatingConnectionFactory() - Constructor for class org.springframework.jms.connection.DelegatingConnectionFactory
 
DestinationResolutionException - Exception in org.springframework.jms.support.destination
Thrown by a DestinationResolver when it cannot resolve a destination name.
DestinationResolutionException(String) - Constructor for exception org.springframework.jms.support.destination.DestinationResolutionException
Create a new DestinationResolutionException.
DestinationResolutionException(String, Throwable) - Constructor for exception org.springframework.jms.support.destination.DestinationResolutionException
Create a new DestinationResolutionException.
DestinationResolver - Interface in org.springframework.jms.support.destination
Strategy interface for resolving JMS destinations.
destroy() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Close the underlying shared connection.
destroy() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Calls AbstractJmsListeningContainer.shutdown() when the BeanFactory destroys the container instance.
determineActivationSpecClass(ResourceAdapter) - Method in class org.springframework.jms.listener.endpoint.DefaultJmsActivationSpecFactory
This implementation guesses the ActivationSpec class name from the provider's class name: e.g.
determineActivationSpecClass(ResourceAdapter) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Determine the ActivationSpec class for the given ResourceAdapter, if possible.
doBegin(Object, TransactionDefinition) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doConvertFromMessage(Message) - Method in class org.springframework.jms.core.JmsTemplate
Extract the content from the given JMS message.
doCreateConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Create a JMS Connection via this template's ConnectionFactory.
doCreateConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
This implementation delegates to the createConnection(username, password) method of the target ConnectionFactory, passing in the specified user credentials.
doCreateProducer(Session, Destination) - Method in class org.springframework.jms.core.JmsTemplate
Create a raw JMS MessageProducer for the given Session and Destination.
doCreateQueueConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
This implementation delegates to the createQueueConnection(username, password) method of the target QueueConnectionFactory, passing in the specified user credentials.
doCreateTopicConnection(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
This implementation delegates to the createTopicConnection(username, password) method of the target TopicConnectionFactory, passing in the specified user credentials.
doExecuteListener(Session, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Execute the specified listener, committing or rolling back the transaction afterwards (if necessary).
doExecuteRequest(Session, Queue, Message) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Actually execute the given request, sending the invoker request message to the specified target queue and waiting for a corresponding response.
doGetTransaction() - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doGetTransactionalSession(ConnectionFactory, ConnectionFactoryUtils.ResourceFactory) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Obtain a JMS Session that is synchronized with the current transaction, if any.
doGetTransactionalSession(ConnectionFactory, ConnectionFactoryUtils.ResourceFactory, boolean) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Obtain a JMS Session that is synchronized with the current transaction, if any.
doInitialize() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Register any invokers within this container.
doInitialize() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Creates the specified number of concurrent consumers, in the form of a JMS Session plus associated MessageConsumer running in a separate thread.
doInitialize() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Creates the specified number of concurrent consumers, in the form of a JMS Session plus associated MessageConsumer.
doInJms(Session, QueueBrowser) - Method in interface org.springframework.jms.core.BrowserCallback
Perform operations on the given Session and QueueBrowser.
doInJms(Session, MessageProducer) - Method in interface org.springframework.jms.core.ProducerCallback
Perform operations on the given Session and MessageProducer.
doInJms(Session) - Method in interface org.springframework.jms.core.SessionCallback
Execute any number of operations against the supplied JMS Session, possibly returning a result.
doInvokeListener(SessionAwareMessageListener, Session, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Invoke the specified listener as Spring SessionAwareMessageListener, exposing a new JMS Session (potentially with its own transaction) to the listener if demanded.
doInvokeListener(MessageListener, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Invoke the specified listener as standard JMS MessageListener.
doReceive(Session, Destination, String) - Method in class org.springframework.jms.core.JmsTemplate
Receive a JMS message.
doReceive(Session, MessageConsumer) - Method in class org.springframework.jms.core.JmsTemplate
Actually receive a JMS message.
doReceiveAndExecute(Object, Session, MessageConsumer, TransactionStatus) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Actually execute the listener for a message received from the given consumer, fetching all requires resources and invoking the listener.
doRescheduleTask(Object) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Reschedule the given task object immediately.
doRescheduleTask(Object) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Re-executes the given task via this listener container's TaskExecutor.
doResume(Object, Object) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doSend(Session, Destination, MessageCreator) - Method in class org.springframework.jms.core.JmsTemplate
Send the given JMS message.
doSend(MessageProducer, Message) - Method in class org.springframework.jms.core.JmsTemplate
Actually send the given JMS message.
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
doShutdown() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Close the registered invokers.
doShutdown() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Destroy the registered JMS Sessions and associated MessageConsumers.
doShutdown() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Destroy the registered JMS Sessions and associated MessageConsumers.
doStart() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Start the shared Connection, if any, and notify all invoker tasks.
doStart() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Re-initializes this container's JMS message consumers, if not initialized already.
doStop() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Notify all invoker tasks and stop the shared Connection, if any.
doSuspend(Object) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
DynamicDestinationResolver - Class in org.springframework.jms.support.destination
Simple DestinationResolver implementation resolving destination names as dynamic destinations.
DynamicDestinationResolver() - Constructor for class org.springframework.jms.support.destination.DynamicDestinationResolver
 

E

establishSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Establish a shared Connection for this container.
establishSharedConnection() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Overridden to accept a failure in the initial setup - leaving it up to the asynchronous invokers to establish the shared Connection on first access.
execute(SessionCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Execute the action specified by the given action object within a JMS Session.
execute(ProducerCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Send messages to the default JMS destination (or one specified for each send operation).
execute(Destination, ProducerCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Send messages to a JMS destination.
execute(String, ProducerCallback<T>) - Method in interface org.springframework.jms.core.JmsOperations
Send messages to a JMS destination.
execute(SessionCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
execute(SessionCallback<T>, boolean) - Method in class org.springframework.jms.core.JmsTemplate
Execute the action specified by the given action object within a JMS Session.
execute(ProducerCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
execute(Destination, ProducerCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
execute(String, ProducerCallback<T>) - Method in class org.springframework.jms.core.JmsTemplate
 
executeListener(Session, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Execute the specified listener, committing or rolling back the transaction afterwards (if necessary).
executeRequest(RemoteInvocation) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Execute the given remote invocation, sending an invoker request message to this accessor's target queue and waiting for a corresponding response.
extractByteArrayFromMessage(BytesMessage) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Extract a byte array from the given BytesMessage.
extractInvocationResult(Message) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Extract the invocation result from the response message.
extractMapFromMessage(MapMessage) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Extract a Map from the given MapMessage.
extractMessage(Message) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Extract the message body from the given JMS message.
extractSerializableFromMessage(ObjectMessage) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Extract a Serializable object from the given ObjectMessage.
extractStringFromMessage(TextMessage) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
Extract a String from the given TextMessage.

F

fromMessage(Message) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
 
fromMessage(Message) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
 
fromMessage(Message) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
This implementation unmarshals the given Message into an object.
fromMessage(Message) - Method in interface org.springframework.jms.support.converter.MessageConverter
Convert from a JMS Message to a Java object.
fromMessage(Message) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
This implementation converts a TextMessage back to a String, a ByteMessage back to a byte array, a MapMessage back to a Map, and an ObjectMessage back to a Serializable object.

G

getAcknowledgeMode() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Return the JMS acknowledgement mode to use.
getActiveConsumerCount() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the number of currently active consumers.
getBeanName() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return the bean name that this listener container has been assigned in its containing bean factory, if any.
getCachedSessionProxy(Session, LinkedList<Session>) - Method in class org.springframework.jms.connection.CachingConnectionFactory
Wrap the given Session with a proxy that delegates every method call to it but adapts close calls.
getCacheLevel() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the level of caching that this listener container is allowed to apply.
getClientId() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Return a JMS client ID for the single Connection created and exposed by this ConnectionFactory, if any.
getClientId() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return the JMS client ID for the shared Connection created and used by this container, if any.
getClientId() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
getConcurrentConsumers() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the "concurrentConsumer" setting.
getConnection(JmsResourceHolder) - Method in interface org.springframework.jms.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Connection from the given JmsResourceHolder.
getConnection() - Method in class org.springframework.jms.connection.JmsResourceHolder
 
getConnection(Class<? extends Connection>) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
getConnection(JmsResourceHolder) - Method in class org.springframework.jms.core.JmsTemplate
Fetch an appropriate Connection from the given JmsResourceHolder.
getConnection(JmsResourceHolder) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Fetch an appropriate Connection from the given JmsResourceHolder.
getConnectionFactory() - Method in class org.springframework.jms.connection.JmsTransactionManager
Return the JMS ConnectionFactory that this instance should manage transactions for.
getConnectionFactory() - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Return the JMS ConnectionFactory used by the gateway.
getConnectionFactory() - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Return the QueueConnectionFactory to use for obtaining JMS QueueConnections.
getConnectionFactory() - Method in class org.springframework.jms.support.JmsAccessor
Return the ConnectionFactory that this accessor uses for obtaining JMS Connections.
getDefaultDestination() - Method in class org.springframework.jms.core.JmsTemplate
Return the destination to be used on send/receive operations that do not have a destination parameter.
getDefaultDestinationName() - Method in class org.springframework.jms.core.JmsTemplate
Return the destination name to be used on send/receive operations that do not have a destination parameter.
getDefaultListenerMethod() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Return the name of the default listener method to delegate to.
getDefaultSubscriptionName(Object) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Determine the default subscription name for the given message listener.
getDelegate() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Return the target object to delegate message listening to.
getDelegates() - Method in class org.springframework.jms.connection.ChainedExceptionListener
Return all registered ExceptionListener delegates (as array).
getDeliveryDelay() - Method in class org.springframework.jms.core.JmsTemplate
Return the delivery delay to use for send calls (in milliseconds).
getDeliveryMode() - Method in class org.springframework.jms.core.JmsTemplate
Return the delivery mode to use when sending a message.
getDestination() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the destination to receive messages from.
getDestinationDescription() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return a descriptive String for this container's JMS destination (never null).
getDestinationName() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the name of the destination to receive messages from.
getDestinationName() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
getDestinationResolver() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Return the DestinationResolver for this adapter.
getDestinationResolver() - Method in class org.springframework.jms.support.destination.JmsDestinationAccessor
Return the DestinationResolver for this accessor (never null).
getDurableSubscriptionName() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the name of a durable subscription to create, if any.
getDurableSubscriptionName() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
getErrorCode() - Method in exception org.springframework.jms.JmsException
Convenience method to get the vendor specific error code if the root cause was an instance of JMSException.
getExceptionListener() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Return the JMS ExceptionListener implementation that should be registered with with the single Connection created by this factory, if any.
getExceptionListener() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the JMS ExceptionListener to notify in case of a JMSException thrown by the registered message listener or the invocation infrastructure, if any.
getIdleConsumerLimit() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the limit for the number of idle consumers.
getIdleTaskExecutionLimit() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the limit for idle executions of a consumer task.
getJavaTypeForMessage(Message) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Determine a Jackson JavaType for the given JMS Message, typically parsing a type id message property.
getJavaTypeForMessage(Message) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Determine a Jackson JavaType for the given JMS Message, typically parsing a type id message property.
getJmsTemplate() - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Return the JmsTemplate for the gateway.
getListenerMethodName(Message, Object) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Determine the name of the listener method that is supposed to handle the given message.
getMaxConcurrency() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Return the maximum number of consumers/sessions to use.
getMaxConcurrentConsumers() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the "maxConcurrentConsumer" setting.
getMaxMessagesPerTask() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the maximum number of messages to process in one task.
getMessage() - Method in exception org.springframework.jms.JmsException
Return the detail message, including the message from the linked exception if there is one.
getMessageConverter() - Method in class org.springframework.jms.core.JmsTemplate
Return the message converter for this template.
getMessageConverter() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Return the converter that will convert incoming JMS messages to listener method arguments, and objects returned from listener methods back to JMS messages.
getMessageListener() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the message listener object to register.
getMessageSelector() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return the JMS message selector expression (or null if none).
getMessageSelector() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
getObject() - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
getObjectType() - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
getPausedTaskCount() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Determine the number of currently paused tasks, if any.
getPhase() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return the phase in which this container will be started and stopped.
getPrefetchSize() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Return the maximum number of messages to load into a session.
getPriority() - Method in class org.springframework.jms.core.JmsTemplate
Return the priority of a message when sending.
getReceiveTimeout() - Method in class org.springframework.jms.core.JmsTemplate
Return the timeout to use for receive calls (in milliseconds).
getReceiveTimeout() - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Return the timeout to use for receiving the response message for a request (in milliseconds).
getResourceFactory() - Method in class org.springframework.jms.connection.JmsTransactionManager
 
getResponseDestination(Message, Message, Session) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Determine a response destination for the given message.
getScheduledConsumerCount() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return the number of currently scheduled consumers.
getSession(Connection, Integer) - Method in class org.springframework.jms.connection.CachingConnectionFactory
Checks for a cached Session for the given mode.
getSession(JmsResourceHolder) - Method in interface org.springframework.jms.connection.ConnectionFactoryUtils.ResourceFactory
Fetch an appropriate Session from the given JmsResourceHolder.
getSession() - Method in class org.springframework.jms.connection.JmsResourceHolder
 
getSession(Class<? extends Session>) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
getSession(Class<? extends Session>, Connection) - Method in class org.springframework.jms.connection.JmsResourceHolder
 
getSession(Connection, Integer) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Template method for obtaining a (potentially cached) Session.
getSession(JmsResourceHolder) - Method in class org.springframework.jms.core.JmsTemplate
Fetch an appropriate Session from the given JmsResourceHolder.
getSession(JmsResourceHolder) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Fetch an appropriate Session from the given JmsResourceHolder.
getSessionAcknowledgeMode() - Method in class org.springframework.jms.support.JmsAccessor
Return the acknowledgement mode for JMS sessions.
getSessionCacheSize() - Method in class org.springframework.jms.connection.CachingConnectionFactory
Return the desired size for the JMS Session cache (per JMS Session type).
getSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return the shared JMS Connection maintained by this container.
getSharedConnectionProxy(Connection) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Wrap the given Connection with a proxy that delegates every method call to it but suppresses close calls.
getSubscriptionName() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
 
getSubscriptionName() - Method in interface org.springframework.jms.listener.SubscriptionNameProvider
Determine the subscription name for this message listener object.
getTargetConnectionFactory() - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
Return the target ConnectionFactory that this ConnectionFactory delegates to.
getTargetConnectionFactory() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Return the target ConnectionFactory which will be used to lazily create a single Connection, if any.
getTargetConnectionFactory() - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Return the target ConnectionFactory that this ConnectionFactory should delegate to.
getTargetSession(Session) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Return the innermost target Session of the given Session.
getTargetSession() - Method in interface org.springframework.jms.connection.SessionProxy
Return the target Session of this proxy.
getTimeToLive() - Method in class org.springframework.jms.core.JmsTemplate
Return the time-to-live of the message when sending.
getTransactionalQueueSession(QueueConnectionFactory, QueueConnection, boolean) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Obtain a JMS QueueSession that is synchronized with the current transaction, if any.
getTransactionalSession(ConnectionFactory, Connection, boolean) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Obtain a JMS Session that is synchronized with the current transaction, if any.
getTransactionalTopicSession(TopicConnectionFactory, TopicConnection, boolean) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Obtain a JMS TopicSession that is synchronized with the current transaction, if any.
getTransactionAwareConnectionProxy(Connection) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Wrap the given Connection with a proxy that delegates every method call to it but handles Session lookup in a transaction-aware fashion.
getTransactionManager() - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Return the Spring PlatformTransactionManager to use for transactional wrapping of message reception plus listener execution.

H

handleListenerException(Throwable) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Handle the given exception that arose during listener execution.
handleListenerException(Throwable) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Handle the given exception that arose during listener execution.
handleListenerSetupFailure(Throwable, boolean) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Handle the given exception that arose during setup of a listener.
handleResult(Object, Message, Session) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Handle the given result object returned from the listener method, sending a response message back.

I

IllegalStateException - Exception in org.springframework.jms
Runtime exception mirroring the JMS IllegalStateException.
IllegalStateException(IllegalStateException) - Constructor for exception org.springframework.jms.IllegalStateException
 
init() - Method in class org.springframework.jms.config.JmsNamespaceHandler
 
initConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Initialize the underlying shared Connection.
initDefaultStrategies() - Method in class org.springframework.jms.core.JmsTemplate
Initialize the default implementations for the template's strategies: DynamicDestinationResolver and SimpleMessageConverter.
initDefaultStrategies() - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Initialize the default implementations for the adapter's strategies.
initGateway() - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Subclasses can override this for custom initialization behavior.
initialize() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Initialize this container.
initialize() - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
 
initialize() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
 
initializeConsumers() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Initialize the JMS Sessions and MessageConsumers for this container.
InvalidClientIDException - Exception in org.springframework.jms
Runtime exception mirroring the JMS InvalidClientIDException.
InvalidClientIDException(InvalidClientIDException) - Constructor for exception org.springframework.jms.InvalidClientIDException
 
InvalidDestinationException - Exception in org.springframework.jms
Runtime exception mirroring the JMS InvalidDestinationException.
InvalidDestinationException(InvalidDestinationException) - Constructor for exception org.springframework.jms.InvalidDestinationException
 
InvalidSelectorException - Exception in org.springframework.jms
Runtime exception mirroring the JMS InvalidSelectorException.
InvalidSelectorException(InvalidSelectorException) - Constructor for exception org.springframework.jms.InvalidSelectorException
 
invoke(MethodInvocation) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
 
invokeErrorHandler(Throwable) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Invoke the registered ErrorHandler, if any.
invokeExceptionListener(JMSException) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Invoke the registered JMS ExceptionListener, if any.
invokeListener(Session, Message) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Invoke the specified listener: either as standard JMS MessageListener or (preferably) as Spring SessionAwareMessageListener.
invokeListenerMethod(String, Object[]) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Invoke the specified listener method.
isAcceptMessagesWhileStopping() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return whether to accept received messages while the listener container in the process of stopping.
isActive() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return whether this container is currently active, that is, whether it has been set up but not shut down yet.
isAutoStartup() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
 
isCacheConsumers() - Method in class org.springframework.jms.connection.CachingConnectionFactory
Return whether to cache JMS MessageConsumers per JMS Session instance.
isCacheProducers() - Method in class org.springframework.jms.connection.CachingConnectionFactory
Return whether to cache JMS MessageProducers per JMS Session instance.
isClientAcknowledge(Session) - Method in class org.springframework.jms.support.JmsAccessor
Determine whether the given Session is in client acknowledge mode.
isExistingTransaction(Object) - Method in class org.springframework.jms.connection.JmsTransactionManager
 
isExplicitQosEnabled() - Method in class org.springframework.jms.core.JmsTemplate
If "true", then the values of deliveryMode, priority, and timeToLive will be used when sending a message.
isExposeListenerSession() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return whether to expose the listener JMS Session to a registered SessionAwareMessageListener.
isFrozen() - Method in class org.springframework.jms.connection.JmsResourceHolder
 
isMessageIdEnabled() - Method in class org.springframework.jms.core.JmsTemplate
Return whether message IDs are enabled.
isMessageTimestampEnabled() - Method in class org.springframework.jms.core.JmsTemplate
Return whether message timestamps are enabled.
isPubSubDomain() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
isPubSubDomain() - Method in class org.springframework.jms.support.destination.JmsDestinationAccessor
Return whether the Publish/Subscribe domain (Topics) is used.
isPubSubNoLocal() - Method in class org.springframework.jms.core.JmsTemplate
Return whether to inhibit the delivery of messages published by its own connection.
isPubSubNoLocal() - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Return whether to inhibit the delivery of messages published by its own connection.
isPubSubNoLocal() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Return whether to inhibit the delivery of messages published by its own connection.
isReconnectOnException() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Return whether the single Connection should be renewed when a JMSException is reported by the underlying Connection.
isRecovering() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return whether this listener container is currently in a recovery attempt.
isRegisteredWithDestination() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Return whether at least one consumer has entered a fixed registration with the target destination.
isRunning() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Determine whether this container is currently running, that is, whether it has been started and not stopped yet.
isSessionLocallyTransacted(Session) - Method in class org.springframework.jms.core.JmsTemplate
Check whether the given Session is locally transacted, that is, whether its transaction is managed by this listener container's Session handling and not by an external transaction coordinator.
isSessionLocallyTransacted(Session) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Check whether the given Session is locally transacted, that is, whether its transaction is managed by this listener container's Session handling and not by an external transaction coordinator.
isSessionLocallyTransacted(Session) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
This implementation checks whether the Session is externally synchronized.
isSessionTransacted() - Method in class org.springframework.jms.support.JmsAccessor
Return whether the JMS sessions used by this accessor are supposed to be transacted.
isSessionTransactional(Session, ConnectionFactory) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Determine whether the given JMS Session is transactional, that is, bound to the current thread by Spring's transaction facilities.
isSingleton() - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
isSubscriptionDurable() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Return whether to make the subscription durable.
isSubscriptionDurable() - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
isSynchedLocalTransactionAllowed() - Method in interface org.springframework.jms.connection.ConnectionFactoryUtils.ResourceFactory
Return whether to allow for a local JMS transaction that is synchronized with a Spring-managed transaction (where the main transaction might be a JDBC-based one for a specific DataSource, for example), with the JMS transaction committing right after the main transaction.
isSynchedLocalTransactionAllowed() - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Return whether to allow for a local JMS transaction that is synchronized with a Spring-managed transaction.

J

JmsAccessor - Class in org.springframework.jms.support
Base class for JmsTemplate and other JMS-accessing gateway helpers, defining common properties such as the JMS ConnectionFactory to operate on.
JmsAccessor() - Constructor for class org.springframework.jms.support.JmsAccessor
 
JmsActivationSpecConfig - Class in org.springframework.jms.listener.endpoint
Common configuration object for activating a JMS message endpoint.
JmsActivationSpecConfig() - Constructor for class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
JmsActivationSpecFactory - Interface in org.springframework.jms.listener.endpoint
Strategy interface for creating JCA 1.5 ActivationSpec objects based on a configured JmsActivationSpecConfig object.
JmsDestinationAccessor - Class in org.springframework.jms.support.destination
Base class for JmsTemplate and other JMS-accessing gateway helpers, adding destination-related properties to JmsAccessor's common properties.
JmsDestinationAccessor() - Constructor for class org.springframework.jms.support.destination.JmsDestinationAccessor
 
JmsException - Exception in org.springframework.jms
Base class for exception thrown by the framework whenever it encounters a problem related to JMS.
JmsException(String) - Constructor for exception org.springframework.jms.JmsException
Constructor that takes a message.
JmsException(String, Throwable) - Constructor for exception org.springframework.jms.JmsException
Constructor that takes a message and a root cause.
JmsException(Throwable) - Constructor for exception org.springframework.jms.JmsException
Constructor that takes a plain root cause, intended for subclasses mirroring corresponding javax.jms exceptions.
JmsGatewaySupport - Class in org.springframework.jms.core.support
Convenient super class for application classes that need JMS access.
JmsGatewaySupport() - Constructor for class org.springframework.jms.core.support.JmsGatewaySupport
 
JmsInvokerClientInterceptor - Class in org.springframework.jms.remoting
MethodInterceptor for accessing a JMS-based remote service.
JmsInvokerClientInterceptor() - Constructor for class org.springframework.jms.remoting.JmsInvokerClientInterceptor
 
JmsInvokerProxyFactoryBean - Class in org.springframework.jms.remoting
FactoryBean for JMS invoker proxies.
JmsInvokerProxyFactoryBean() - Constructor for class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
JmsInvokerServiceExporter - Class in org.springframework.jms.remoting
JMS message listener that exports the specified service bean as a JMS service endpoint, accessible via a JMS invoker proxy.
JmsInvokerServiceExporter() - Constructor for class org.springframework.jms.remoting.JmsInvokerServiceExporter
 
JmsMessageEndpointFactory - Class in org.springframework.jms.listener.endpoint
JMS-specific implementation of the JCA 1.5 MessageEndpointFactory interface, providing transaction management capabilities for a JMS listener object (e.g.
JmsMessageEndpointFactory() - Constructor for class org.springframework.jms.listener.endpoint.JmsMessageEndpointFactory
 
JmsMessageEndpointFactory.JmsResourceException - Exception in org.springframework.jms.listener.endpoint
Internal exception thrown when a ResourceException has been encountered during the endpoint invocation.
JmsMessageEndpointManager - Class in org.springframework.jms.listener.endpoint
Extension of the generic JCA 1.5 GenericMessageEndpointManager, adding JMS-specific support for ActivationSpec configuration.
JmsMessageEndpointManager() - Constructor for class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
 
JmsNamespaceHandler - Class in org.springframework.jms.config
A NamespaceHandler for the JMS namespace.
JmsNamespaceHandler() - Constructor for class org.springframework.jms.config.JmsNamespaceHandler
 
JmsOperations - Interface in org.springframework.jms.core
Specifies a basic set of JMS operations.
JmsResourceException(ResourceException) - Constructor for exception org.springframework.jms.listener.endpoint.JmsMessageEndpointFactory.JmsResourceException
 
JmsResourceHolder - Class in org.springframework.jms.connection
JMS resource holder, wrapping a JMS Connection and a JMS Session.
JmsResourceHolder() - Constructor for class org.springframework.jms.connection.JmsResourceHolder
Create a new JmsResourceHolder that is open for resources to be added.
JmsResourceHolder(ConnectionFactory) - Constructor for class org.springframework.jms.connection.JmsResourceHolder
Create a new JmsResourceHolder that is open for resources to be added.
JmsResourceHolder(Session) - Constructor for class org.springframework.jms.connection.JmsResourceHolder
Create a new JmsResourceHolder for the given JMS Session.
JmsResourceHolder(Connection, Session) - Constructor for class org.springframework.jms.connection.JmsResourceHolder
Create a new JmsResourceHolder for the given JMS resources.
JmsResourceHolder(ConnectionFactory, Connection, Session) - Constructor for class org.springframework.jms.connection.JmsResourceHolder
Create a new JmsResourceHolder for the given JMS resources.
JmsSecurityException - Exception in org.springframework.jms
Runtime exception mirroring the JMS JMSSecurityException.
JmsSecurityException(JMSSecurityException) - Constructor for exception org.springframework.jms.JmsSecurityException
 
JmsTemplate - Class in org.springframework.jms.core
Helper class that simplifies synchronous JMS access code.
JmsTemplate() - Constructor for class org.springframework.jms.core.JmsTemplate
Create a new JmsTemplate for bean-style usage.
JmsTemplate(ConnectionFactory) - Constructor for class org.springframework.jms.core.JmsTemplate
Create a new JmsTemplate, given a ConnectionFactory.
JmsTransactionManager - Class in org.springframework.jms.connection
PlatformTransactionManager implementation for a single JMS ConnectionFactory.
JmsTransactionManager() - Constructor for class org.springframework.jms.connection.JmsTransactionManager
Create a new JmsTransactionManager for bean-style usage.
JmsTransactionManager(ConnectionFactory) - Constructor for class org.springframework.jms.connection.JmsTransactionManager
Create a new JmsTransactionManager, given a ConnectionFactory.
JmsUtils - Class in org.springframework.jms.support
Generic utility methods for working with JMS.
JmsUtils() - Constructor for class org.springframework.jms.support.JmsUtils
 
JndiDestinationResolver - Class in org.springframework.jms.support.destination
DestinationResolver implementation which interprets destination names as JNDI locations (with a configurable fallback strategy).
JndiDestinationResolver() - Constructor for class org.springframework.jms.support.destination.JndiDestinationResolver
 

L

lifecycleMonitor - Variable in class org.springframework.jms.listener.AbstractJmsListeningContainer
 
ListenerExecutionFailedException - Exception in org.springframework.jms.listener.adapter
Exception to be thrown when the execution of a listener method failed.
ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.jms.listener.adapter.ListenerExecutionFailedException
Constructor for ListenerExecutionFailedException.
logger - Variable in class org.springframework.jms.connection.SingleConnectionFactory
 
logger - Variable in class org.springframework.jms.core.support.JmsGatewaySupport
Logger available to subclasses
logger - Variable in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Logger available to subclasses
logger - Variable in class org.springframework.jms.listener.endpoint.DefaultJmsActivationSpecFactory
Logger available to subclasses
logger - Variable in class org.springframework.jms.support.JmsAccessor
Logger available to subclasses
logRejectedTask(Object, RuntimeException) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer

M

MappingJackson2MessageConverter - Class in org.springframework.jms.support.converter
Message converter that uses Jackson 2.x to convert messages to and from JSON.
MappingJackson2MessageConverter() - Constructor for class org.springframework.jms.support.converter.MappingJackson2MessageConverter
 
MappingJacksonMessageConverter - Class in org.springframework.jms.support.converter
Deprecated.
Please migrate to MappingJackson2MessageConverter for Jackson 2.x.
MappingJacksonMessageConverter() - Constructor for class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
 
mapToBytesMessage(Object, Session, ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Map the given object to a BytesMessage.
mapToBytesMessage(Object, Session, ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Map the given object to a BytesMessage.
mapToMessage(Object, Session, ObjectMapper, MessageType) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Template method that allows for custom message mapping.
mapToMessage(Object, Session, ObjectMapper, MessageType) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Template method that allows for custom message mapping.
mapToTextMessage(Object, Session, ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Map the given object to a TextMessage.
mapToTextMessage(Object, Session, ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Map the given object to a TextMessage.
MarshallingMessageConverter - Class in org.springframework.jms.support.converter
Spring JMS MessageConverter that uses a Marshaller and Unmarshaller.
MarshallingMessageConverter() - Constructor for class org.springframework.jms.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with no Marshaller or Unmarshaller set.
MarshallingMessageConverter(Marshaller) - Constructor for class org.springframework.jms.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller set.
MarshallingMessageConverter(Marshaller, Unmarshaller) - Constructor for class org.springframework.jms.support.converter.MarshallingMessageConverter
Construct a new MarshallingMessageConverter with the given Marshaller and Unmarshaller.
marshalToBytesMessage(Object, Session, Marshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Marshal the given object to a BytesMessage.
marshalToMessage(Object, Session, Marshaller, MessageType) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Template method that allows for custom message marshalling.
marshalToTextMessage(Object, Session, Marshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Marshal the given object to a TextMessage.
MessageConversionException - Exception in org.springframework.jms.support.converter
Thrown by MessageConverter implementations when the conversion of an object to/from a Message fails.
MessageConversionException(String) - Constructor for exception org.springframework.jms.support.converter.MessageConversionException
Create a new MessageConversionException.
MessageConversionException(String, Throwable) - Constructor for exception org.springframework.jms.support.converter.MessageConversionException
Create a new MessageConversionException.
MessageConverter - Interface in org.springframework.jms.support.converter
Strategy interface that specifies a converter between Java objects and JMS messages.
MessageCreator - Interface in org.springframework.jms.core
Creates a JMS message given a Session.
MessageEOFException - Exception in org.springframework.jms
Runtime exception mirroring the JMS MessageEOFException.
MessageEOFException(MessageEOFException) - Constructor for exception org.springframework.jms.MessageEOFException
 
MessageFormatException - Exception in org.springframework.jms
Runtime exception mirroring the JMS MessageFormatException.
MessageFormatException(MessageFormatException) - Constructor for exception org.springframework.jms.MessageFormatException
 
MessageListenerAdapter - Class in org.springframework.jms.listener.adapter
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with flexible message type conversion.
MessageListenerAdapter() - Constructor for class org.springframework.jms.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter with default settings.
MessageListenerAdapter(Object) - Constructor for class org.springframework.jms.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
MessageNotReadableException - Exception in org.springframework.jms
Runtime exception mirroring the JMS MessageNotReadableException.
MessageNotReadableException(MessageNotReadableException) - Constructor for exception org.springframework.jms.MessageNotReadableException
 
MessageNotWriteableException - Exception in org.springframework.jms
Runtime exception mirroring the JMS MessageNotWriteableException.
MessageNotWriteableException(MessageNotWriteableException) - Constructor for exception org.springframework.jms.MessageNotWriteableException
 
MessagePostProcessor - Interface in org.springframework.jms.core
To be used with JmsTemplate's send method that convert an object to a message.
messageReceived(Object, Session) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Template method that gets called right when a new message has been received, before attempting to process it.
messageReceived(Object, Session) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Tries scheduling a new invoker, since we know messages are coming in...
MessageType - Enum in org.springframework.jms.support.converter
Constants that indicate a target message type to convert to: a TextMessage, a BytesMessage, a MapMessage or an ObjectMessage.

N

noMessageReceived(Object, Session) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Template method that gets called when no message has been received, before returning to the receive loop again.
noMessageReceived(Object, Session) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Marks the affected invoker as idle.

O

onException(JMSException) - Method in class org.springframework.jms.connection.ChainedExceptionListener
 
onException(JMSException) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Exception listener callback that renews the underlying single Connection.
onException(JMSException) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
JMS ExceptionListener implementation, invoked by the JMS provider in case of connection failures.
onInvalidRequest(Message) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Callback that is invoked by JmsInvokerServiceExporter.readRemoteInvocation(javax.jms.Message) when it encounters an invalid request message.
onInvalidResponse(Message) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Callback that is invoked by extractInvocationResult when it encounters an invalid response message.
onMessage(Message) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Standard JMS MessageListener entry point.
onMessage(Message, Session) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Spring SessionAwareMessageListener entry point.
onMessage(M, Session) - Method in interface org.springframework.jms.listener.SessionAwareMessageListener
Callback for processing a received JMS message.
onMessage(Message, Session) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
 
org.springframework.jms - package org.springframework.jms
This package contains integration classes for JMS, allowing for Spring-style JMS access.
org.springframework.jms.config - package org.springframework.jms.config
Support package for declarative messaging configuration, with XML schema being the primary configuration format.
org.springframework.jms.connection - package org.springframework.jms.connection
Provides a PlatformTransactionManager implementation for a single JMS ConnectionFactory, and a SingleConnectionFactory adapter.
org.springframework.jms.core - package org.springframework.jms.core
Core package of the JMS support.
org.springframework.jms.core.support - package org.springframework.jms.core.support
Classes supporting the org.springframework.jms.core package.
org.springframework.jms.listener - package org.springframework.jms.listener
This package contains the base message listener container facility.
org.springframework.jms.listener.adapter - package org.springframework.jms.listener.adapter
Message listener adapter mechanism that delegates to target listener methods, converting messages to appropriate message content types (such as String or byte array) that get passed into listener methods.
org.springframework.jms.listener.endpoint - package org.springframework.jms.listener.endpoint
This package provides JCA-based endpoint management for JMS message listeners.
org.springframework.jms.remoting - package org.springframework.jms.remoting
Remoting classes for transparent Java-to-Java remoting via a JMS provider.
org.springframework.jms.support - package org.springframework.jms.support
This package provides generic JMS support classes, to be used by higher-level classes like JmsTemplate.
org.springframework.jms.support.converter - package org.springframework.jms.support.converter
Provides a MessageConverter abstraction to convert between Java objects and JMS messages.
org.springframework.jms.support.destination - package org.springframework.jms.support.destination
Support classes for Spring's JMS framework.
ORIGINAL_DEFAULT_LISTENER_METHOD - Static variable in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Out-of-the-box value for the default listener method: "handleMessage".

P

populateActivationSpecProperties(BeanWrapper, JmsActivationSpecConfig) - Method in class org.springframework.jms.listener.endpoint.DefaultJmsActivationSpecFactory
This implementation supports Spring's extended "maxConcurrency" and "prefetchSize" settings through detecting corresponding ActivationSpec properties: "maxSessions"/"maxNumberOfWorks" and "maxMessagesPerSessions"/"maxMessages", respectively (following ActiveMQ's and JORAM's naming conventions).
populateActivationSpecProperties(BeanWrapper, JmsActivationSpecConfig) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Populate the given ApplicationSpec object with the settings defined in the given configuration object.
postProcessMessage(Message) - Method in interface org.springframework.jms.core.MessagePostProcessor
Apply a MessagePostProcessor to the message.
postProcessProducer(MessageProducer, Message) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Post-process the given message producer before using it to send the response.
postProcessResponse(Message, Message) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Post-process the given response message before it will be sent.
prepareConnection(Connection) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Prepare the given Connection before it is exposed.
prepareSharedConnection(Connection) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Prepare the given Connection, which is about to be registered as shared Connection for this container.
prepareSharedConnection(Connection) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Registers this listener container as JMS ExceptionListener on the shared connection.
processMessage(Message, Session) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Process a message received from the provider.
ProducerCallback<T> - Interface in org.springframework.jms.core
Callback for sending a message to a JMS destination.

R

readRemoteInvocation(Message) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Read a RemoteInvocation from the given JMS message.
receive() - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the default destination, but only wait up to a specified time for delivery.
receive(Destination) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receive(String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receive() - Method in class org.springframework.jms.core.JmsTemplate
 
receive(Destination) - Method in class org.springframework.jms.core.JmsTemplate
 
receive(String) - Method in class org.springframework.jms.core.JmsTemplate
 
RECEIVE_TIMEOUT_INDEFINITE_WAIT - Static variable in class org.springframework.jms.core.JmsTemplate
Timeout value indicating a blocking receive without timeout.
RECEIVE_TIMEOUT_NO_WAIT - Static variable in class org.springframework.jms.core.JmsTemplate
Timeout value indicating that a receive operation should check if a message is immediately available without blocking.
receiveAndConvert() - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the default destination, but only wait up to a specified time for delivery.
receiveAndConvert(Destination) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveAndConvert(String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveAndConvert() - Method in class org.springframework.jms.core.JmsTemplate
 
receiveAndConvert(Destination) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveAndConvert(String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveAndExecute(Object, Session, MessageConsumer) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Execute the listener for a message received from the given consumer, wrapping the entire operation in an external transaction if demanded.
receiveMessage(MessageConsumer) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Receive a message from the given consumer.
receiveSelected(String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the default destination, but only wait up to a specified time for delivery.
receiveSelected(Destination, String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveSelected(String, String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveSelected(String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveSelected(Destination, String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveSelected(String, String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveSelectedAndConvert(String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the default destination, but only wait up to a specified time for delivery.
receiveSelectedAndConvert(Destination, String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveSelectedAndConvert(String, String) - Method in interface org.springframework.jms.core.JmsOperations
Receive a message synchronously from the specified destination, but only wait up to a specified time for delivery.
receiveSelectedAndConvert(String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveSelectedAndConvert(Destination, String) - Method in class org.springframework.jms.core.JmsTemplate
 
receiveSelectedAndConvert(String, String) - Method in class org.springframework.jms.core.JmsTemplate
 
recoverAfterListenerSetupFailure() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Recover this listener container after a listener failed to set itself up, for example re-establishing the underlying Connection.
recreateRemoteInvocationResult(RemoteInvocationResult) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Recreate the invocation result contained in the given RemoteInvocationResult object.
refreshConnectionUntilSuccessful() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Refresh the underlying Connection, not returning before an attempt has been successful.
refreshDestination() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Refresh the JMS destination that this listener container operates on.
refreshSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Refresh the shared Connection that this container holds.
releaseConnection(Connection, ConnectionFactory, boolean) - Static method in class org.springframework.jms.connection.ConnectionFactoryUtils
Release the given Connection, stopping it (if necessary) and eventually closing it.
removeCredentialsFromCurrentThread() - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Remove any user credentials for this proxy from the current thread.
removeFromCache(String) - Method in interface org.springframework.jms.support.destination.CachingDestinationResolver
Remove the destination with the given name from the cache (if cached by this resolver in the first place).
removeFromCache(String) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
 
rescheduleTaskIfNecessary(Object) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Take the given task object and reschedule it, either immediately if this container is currently running, or later once this container has been restarted.
resetConnection() - Method in class org.springframework.jms.connection.CachingConnectionFactory
Resets the Session cache as well.
resetConnection() - Method in class org.springframework.jms.connection.SingleConnectionFactory
Reset the underlying shared Connection, to be reinitialized on next access.
resolveDefaultResponseDestination(Session) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Resolve the default response destination into a JMS Destination, using this accessor's DestinationResolver in case of a destination name.
resolveDestinationName(Session, String, boolean) - Method in class org.springframework.jms.support.destination.BeanFactoryDestinationResolver
 
resolveDestinationName(Session, String, boolean) - Method in interface org.springframework.jms.support.destination.DestinationResolver
Resolve the given destination name, either as located resource or as dynamic destination.
resolveDestinationName(Session, String, boolean) - Method in class org.springframework.jms.support.destination.DynamicDestinationResolver
Resolve the specified destination name as a dynamic destination.
resolveDestinationName(Session, String) - Method in class org.springframework.jms.support.destination.JmsDestinationAccessor
Resolve the given destination name into a JMS Destination, via this accessor's DestinationResolver.
resolveDestinationName(Session, String, boolean) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
 
resolveQueue(Session) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Resolve this accessor's target queue.
resolveQueue(Session, String) - Method in class org.springframework.jms.support.destination.DynamicDestinationResolver
Resolve the given destination name to a Queue.
resolveQueueName(Session, String) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Resolve the given queue name into a JMS Queue, via this accessor's DestinationResolver.
resolveTopic(Session, String) - Method in class org.springframework.jms.support.destination.DynamicDestinationResolver
Resolve the given destination name to a Topic.
ResourceAllocationException - Exception in org.springframework.jms
Runtime exception mirroring the JMS ResourceAllocationException.
ResourceAllocationException(ResourceAllocationException) - Constructor for exception org.springframework.jms.ResourceAllocationException
 
resumePausedTasks() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Try to resume all paused tasks.
rollbackIfNecessary(Session) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Perform a rollback, if appropriate.
rollbackIfNecessary(Session) - Static method in class org.springframework.jms.support.JmsUtils
Rollback the Session if not within a JTA transaction.
rollbackOnExceptionIfNecessary(Session, Throwable) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Perform a rollback, handling rollback exceptions properly.
runningAllowed() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Check whether this container's listeners are generally allowed to run.

S

scheduleNewInvokerIfAppropriate() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Schedule a new invoker, increasing the total number of scheduled invokers for this listener container, but only if the specified "maxConcurrentConsumers" limit has not been reached yet, and only if the specified "idleConsumerLimit" has not been reached either.
send(MessageCreator) - Method in interface org.springframework.jms.core.JmsOperations
Send a message to the default destination.
send(Destination, MessageCreator) - Method in interface org.springframework.jms.core.JmsOperations
Send a message to the specified destination.
send(String, MessageCreator) - Method in interface org.springframework.jms.core.JmsOperations
Send a message to the specified destination.
send(MessageCreator) - Method in class org.springframework.jms.core.JmsTemplate
 
send(Destination, MessageCreator) - Method in class org.springframework.jms.core.JmsTemplate
 
send(String, MessageCreator) - Method in class org.springframework.jms.core.JmsTemplate
 
sendResponse(Session, Destination, Message) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Send the given response message to the given destination.
SessionAwareMessageListener<M extends Message> - Interface in org.springframework.jms.listener
Variant of the standard JMS MessageListener interface, offering not only the received Message but also the underlying JMS Session object.
SessionCallback<T> - Interface in org.springframework.jms.core
Callback for executing any number of operations on a provided Session.
SessionProxy - Interface in org.springframework.jms.connection
Subinterface of Session to be implemented by Session proxies.
setAcceptMessagesWhileStopping(boolean) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set whether to accept received messages while the listener container in the process of stopping.
setAcknowledgeMode(int) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Set the JMS acknowledgement mode to use.
setAcknowledgeModeName(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Set the JMS acknowledgement mode by the name of the corresponding constant in the JMS Session interface, e.g.
setActivationSpecClass(Class<?>) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Specify the fully-qualified ActivationSpec class name for the target provider (e.g.
setActivationSpecConfig(JmsActivationSpecConfig) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Specify the JmsActivationSpecConfig object that this endpoint manager should use for activating its listener.
setActivationSpecFactory(JmsActivationSpecFactory) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Set the factory for concrete JCA 1.5 ActivationSpec objects, creating JCA ActivationSpecs based on JmsActivationSpecConfig objects.
setAutoStartup(boolean) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Set whether to automatically start the container after initialization.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
 
setBeanFactory(BeanFactory) - Method in class org.springframework.jms.support.destination.BeanFactoryDestinationResolver
 
setBeanName(String) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
 
setBeanName(String) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Set the name of this message endpoint.
setCache(boolean) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
Set whether to cache resolved destinations.
setCacheConsumers(boolean) - Method in class org.springframework.jms.connection.CachingConnectionFactory
Specify whether to cache JMS MessageConsumers per JMS Session instance (more specifically: one MessageConsumer per Destination, selector String and Session).
setCacheLevel(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the level of caching that this listener container is allowed to apply.
setCacheLevelName(String) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the level of caching that this listener container is allowed to apply, in the form of the name of the corresponding constant: e.g.
setCacheProducers(boolean) - Method in class org.springframework.jms.connection.CachingConnectionFactory
Specify whether to cache JMS MessageProducers per JMS Session instance (more specifically: one MessageProducer per Destination and Session).
setClientId(String) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Specify a JMS client ID for the single Connection created and exposed by this ConnectionFactory.
setClientId(String) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Specify the JMS client ID for a shared Connection created and used by this container.
setClientId(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setConcurrency(String) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify concurrency limits via a "lower-upper" String, e.g.
setConcurrency(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Specify concurrency limits via a "lower-upper" String, e.g.
setConcurrency(String) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Specify concurrency limits via a "lower-upper" String, e.g.
setConcurrentConsumers(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the number of concurrent consumers to create.
setConcurrentConsumers(int) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Specify the number of concurrent consumers to create.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.connection.JmsTransactionManager
Set the JMS ConnectionFactory that this instance should manage transactions for.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Set the JMS connection factory to be used by the gateway.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the QueueConnectionFactory to use for obtaining JMS QueueConnections.
setConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.support.JmsAccessor
Set the ConnectionFactory to use for obtaining JMS Connections.
setConnectLazily(boolean) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Specify whether to connect lazily, i.e.
setCredentialsForCurrentThread(String, String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Set user credententials for this proxy and the current thread.
setDefaultDestination(Destination) - Method in class org.springframework.jms.core.JmsTemplate
Set the destination to be used on send/receive operations that do not have a destination parameter.
setDefaultDestinationName(String) - Method in class org.springframework.jms.core.JmsTemplate
Set the destination name to be used on send/receive operations that do not have a destination parameter.
setDefaultListenerMethod(String) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Specify the name of the default listener method to delegate to, for the case where no specific listener method has been determined.
setDefaultProperties(Map<String, String>) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Specify custom default properties, with String keys and String values.
setDefaultResponseDestination(Destination) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set the default destination to send response messages to.
setDefaultResponseQueueName(String) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set the name of the default response queue to send response messages to.
setDefaultResponseTopicName(String) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set the name of the default response topic to send response messages to.
setDelegate(Object) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set a target object to delegate message listening to.
setDeliveryDelay(long) - Method in class org.springframework.jms.core.JmsTemplate
Set the delivery delay to use for send calls (in milliseconds).
setDeliveryMode(int) - Method in class org.springframework.jms.core.JmsTemplate
Set the delivery mode to use when sending a message.
setDeliveryPersistent(boolean) - Method in class org.springframework.jms.core.JmsTemplate
Set whether message delivery should be persistent or non-persistent, specified as boolean value ("true" or "false").
setDestination(Destination) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the destination to receive messages from.
setDestinationName(String) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the name of the destination to receive messages from.
setDestinationName(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set the DestinationResolver that should be used to resolve response destination names for this adapter.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Set the DestinationResolver to use for resolving destination names into the JCA 1.5 ActivationSpec "destination" property.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
Set the DestinationResolver to use for resolving destination names into the JCA 1.5 ActivationSpec "destination" property.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the DestinationResolver that is to be used to resolve Queue references for this accessor.
setDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.support.destination.JmsDestinationAccessor
Set the DestinationResolver that is to be used to resolve Destination references for this accessor.
setDurableSubscriptionName(String) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the name of a durable subscription to create.
setDurableSubscriptionName(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setDynamicDestinationResolver(DestinationResolver) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
Set the DestinationResolver to use when falling back to dynamic destinations.
setEncoding(String) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Specify the encoding to use when converting to and from text-based message body content.
setEncoding(String) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Specify the encoding to use when converting to and from text-based message body content.
setEncodingPropertyName(String) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Specify the name of the JMS message property that carries the encoding from bytes to String and back is BytesMessage is used during the conversion process.
setEncodingPropertyName(String) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Specify the name of the JMS message property that carries the encoding from bytes to String and back is BytesMessage is used during the conversion process.
setErrorHandler(ErrorHandler) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
setExceptionListener(ExceptionListener) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Specify an JMS ExceptionListener implementation that should be registered with with the single Connection created by this factory.
setExceptionListener(ExceptionListener) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the JMS ExceptionListener to notify in case of a JMSException thrown by the registered message listener or the invocation infrastructure.
setExplicitQosEnabled(boolean) - Method in class org.springframework.jms.core.JmsTemplate
Set if the QOS values (deliveryMode, priority, timeToLive) should be used for sending a message.
setExposeListenerSession(boolean) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set whether to expose the listener JMS Session to a registered SessionAwareMessageListener as well as to JmsTemplate calls.
setFallbackToDynamicDestination(boolean) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
Set whether this resolver is supposed to create dynamic destinations if the destination name is not found in JNDI.
setIdleConsumerLimit(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the limit for the number of consumers that are allowed to be idle at any given time.
setIdleTaskExecutionLimit(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the limit for idle executions of a consumer task, not having received any message within its execution.
setIgnoreInvalidRequests(boolean) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Set whether invalidly formatted messages should be discarded.
setJmsTemplate(JmsTemplate) - Method in class org.springframework.jms.core.support.JmsGatewaySupport
Set the JmsTemplate for the gateway.
setMarshaller(Marshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Set the Marshaller to be used by this message converter.
setMaxConcurrency(int) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Specify the maximum number of consumers/sessions to use, effectively controlling the number of concurrent invocations on the target listener.
setMaxConcurrentConsumers(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the maximum number of concurrent consumers to create.
setMaxMessagesPerTask(int) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the maximum number of messages to process in one task.
setMessageConverter(MessageConverter) - Method in class org.springframework.jms.core.JmsTemplate
Set the message converter for this template.
setMessageConverter(MessageConverter) - Method in class org.springframework.jms.listener.adapter.MessageListenerAdapter
Set the converter that will convert incoming JMS messages to listener method arguments, and objects returned from listener methods back to JMS messages.
setMessageConverter(MessageConverter) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Specify the MessageConverter to use for turning RemoteInvocation objects into request messages, as well as response messages into RemoteInvocationResult objects.
setMessageConverter(MessageConverter) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Specify the MessageConverter to use for turning request messages into RemoteInvocation objects, as well as RemoteInvocationResult objects into response messages.
setMessageIdEnabled(boolean) - Method in class org.springframework.jms.core.JmsTemplate
Set whether message IDs are enabled.
setMessageListener(Object) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the message listener implementation to register.
setMessageListener(MessageListener) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointFactory
Set the JMS MessageListener for this endpoint.
setMessageListener(MessageListener) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Set the JMS MessageListener for this endpoint.
setMessageSelector(String) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set the JMS message selector expression (or null if none).
setMessageSelector(String) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setMessageTimestampEnabled(boolean) - Method in class org.springframework.jms.core.JmsTemplate
Set whether message timestamps are enabled.
setObjectMapper(ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Specify the ObjectMapper to use instead of using the default.
setObjectMapper(ObjectMapper) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Specify the ObjectMapper to use instead of using the default.
setPassword(String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Set the password that this adapter should use for retrieving Connections.
setPhase(int) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Specify the phase in which this container should be started and stopped.
setPrefetchSize(int) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
Specify the maximum number of messages to load into a session (a kind of batch size).
setPriority(int) - Method in class org.springframework.jms.core.JmsTemplate
Set the priority of a message when sending.
setPubSubDomain(boolean) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setPubSubDomain(boolean) - Method in class org.springframework.jms.support.destination.JmsDestinationAccessor
Configure the destination accessor with knowledge of the JMS domain used.
setPubSubNoLocal(boolean) - Method in class org.springframework.jms.core.JmsTemplate
Set whether to inhibit the delivery of messages published by its own connection.
setPubSubNoLocal(boolean) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Set whether to inhibit the delivery of messages published by its own connection.
setPubSubNoLocal(boolean) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Set whether to inhibit the delivery of messages published by its own connection.
setQueue(Queue) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the target Queue to send invoker requests to.
setQueueName(String) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the name of target queue to send invoker requests to.
setReceiveTimeout(long) - Method in class org.springframework.jms.core.JmsTemplate
Set the timeout to use for receive calls (in milliseconds).
setReceiveTimeout(long) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Set the timeout to use for receive calls, in milliseconds.
setReceiveTimeout(long) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the timeout to use for receiving the response message for a request (in milliseconds).
setReconnectOnException(boolean) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Specify whether the single Connection should be reset (to be subsequently renewed) when a JMSException is reported by the underlying Connection.
setRecoveryInterval(long) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Specify the interval between recovery attempts, in milliseconds.
setRemoteInvocationFactory(RemoteInvocationFactory) - Method in class org.springframework.jms.remoting.JmsInvokerClientInterceptor
Set the RemoteInvocationFactory to use for this accessor.
setServiceInterface(Class<?>) - Method in class org.springframework.jms.remoting.JmsInvokerProxyFactoryBean
Set the interface that the proxy must implement.
setSessionAcknowledgeMode(int) - Method in class org.springframework.jms.support.JmsAccessor
Set the JMS acknowledgement mode that is used when creating a JMS Session to send a message.
setSessionAcknowledgeModeName(String) - Method in class org.springframework.jms.support.JmsAccessor
Set the JMS acknowledgement mode by the name of the corresponding constant in the JMS Session interface, e.g.
setSessionCacheSize(int) - Method in class org.springframework.jms.connection.CachingConnectionFactory
Specify the desired size for the JMS Session cache (per JMS Session type).
setSessionTransacted(boolean) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
 
setSessionTransacted(boolean) - Method in class org.springframework.jms.support.JmsAccessor
Set the transaction mode that is used when creating a JMS Session.
setShouldStopConnections(boolean) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
Indicate whether Connections obtained from the target factory are supposed to be stopped before closed ("true") or simply closed ("false").
setSubscriptionDurable(boolean) - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
Set whether to make the subscription durable.
setSubscriptionDurable(boolean) - Method in class org.springframework.jms.listener.endpoint.JmsActivationSpecConfig
 
setSynchedLocalTransactionAllowed(boolean) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Set whether to allow for a local JMS transaction that is synchronized with a Spring-managed transaction (where the main transaction might be a JDBC-based one for a specific DataSource, for example), with the JMS transaction committing right after the main transaction.
setTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
Set the target ConnectionFactory that this ConnectionFactory should delegate to.
setTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.connection.SingleConnectionFactory
Set the target ConnectionFactory which will be used to lazily create a single Connection.
setTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Set the target ConnectionFactory that this ConnectionFactory should delegate to.
setTargetConnectionFactory(ConnectionFactory) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Set the target ConnectionFactory that this ConnectionFactory should delegate to.
setTargetType(MessageType) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
setTargetType(MessageType) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
setTargetType(MessageType) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
setTaskExecutor(Executor) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Set the Spring TaskExecutor to use for running the listener threads.
setTaskExecutor(Executor) - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Set the Spring TaskExecutor to use for executing the listener once a message has been received by the provider.
setTimeToLive(long) - Method in class org.springframework.jms.core.JmsTemplate
Set the time-to-live of the message when sending.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Specify the Spring PlatformTransactionManager to use for transactional wrapping of message reception plus listener execution.
setTransactionManager(Object) - Method in class org.springframework.jms.listener.endpoint.JmsMessageEndpointManager
Set the XA transaction manager to use for wrapping endpoint invocations, enlisting the endpoint resource in each such transaction.
setTransactionName(String) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Specify the transaction name to use for transactional wrapping.
setTransactionTimeout(int) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Specify the transaction timeout to use for transactional wrapping, in seconds.
setTypeIdMappings(Map<String, Class<?>>) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Specify mappings from type ids to Java classes, if desired.
setTypeIdMappings(Map<String, Class<?>>) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Specify mappings from type ids to Java classes, if desired.
setTypeIdOnMessage(Object, Message) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Set a type id for the given payload object on the given JMS Message.
setTypeIdOnMessage(Object, Message) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Set a type id for the given payload object on the given JMS Message.
setTypeIdPropertyName(String) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
Specify the name of the JMS message property that carries the type id for the contained object: either a mapped id value or a raw Java class name.
setTypeIdPropertyName(String) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
Specify the name of the JMS message property that carries the type id for the contained object: either a mapped id value or a raw Java class name.
setUnmarshaller(Unmarshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Set the Unmarshaller to be used by this message converter.
setUsername(String) - Method in class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
Set the username that this adapter should use for retrieving Connections.
sharedConnectionEnabled() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Return whether a shared JMS Connection should be maintained by this container base class.
sharedConnectionEnabled() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Use a shared JMS Connection depending on the "cacheLevel" setting.
sharedConnectionEnabled() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
Always use a shared JMS Connection.
sharedConnectionMonitor - Variable in class org.springframework.jms.listener.AbstractJmsListeningContainer
 
SharedConnectionNotInitializedException(String) - Constructor for exception org.springframework.jms.listener.AbstractJmsListeningContainer.SharedConnectionNotInitializedException
Create a new SharedConnectionNotInitializedException.
shouldCommitAfterNoMessageReceived(Session) - Method in class org.springframework.jms.listener.AbstractPollingMessageListenerContainer
Determine whether to trigger a commit after no message has been received.
shouldStop(Connection) - Method in class org.springframework.jms.connection.DelegatingConnectionFactory
 
shouldStop(Connection) - Method in interface org.springframework.jms.connection.SmartConnectionFactory
Should we stop the Connection, obtained from this ConnectionFactory?
shutdown() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Stop the shared Connection, call AbstractJmsListeningContainer.doShutdown(), and close this container.
SimpleMessageConverter - Class in org.springframework.jms.support.converter
A simple message converter which is able to handle TextMessages, BytesMessages, MapMessages, and ObjectMessages.
SimpleMessageConverter() - Constructor for class org.springframework.jms.support.converter.SimpleMessageConverter
 
SimpleMessageListenerContainer - Class in org.springframework.jms.listener
Message listener container that uses the plain JMS client API's MessageConsumer.setMessageListener() method to create concurrent MessageConsumers for the specified listeners.
SimpleMessageListenerContainer() - Constructor for class org.springframework.jms.listener.SimpleMessageListenerContainer
 
SingleConnectionFactory - Class in org.springframework.jms.connection
A JMS ConnectionFactory adapter that returns the same Connection from all SingleConnectionFactory.createConnection() calls, and ignores calls to Connection.close().
SingleConnectionFactory() - Constructor for class org.springframework.jms.connection.SingleConnectionFactory
Create a new SingleConnectionFactory for bean-style usage.
SingleConnectionFactory(Connection) - Constructor for class org.springframework.jms.connection.SingleConnectionFactory
Create a new SingleConnectionFactory that always returns the given Connection.
SingleConnectionFactory(ConnectionFactory) - Constructor for class org.springframework.jms.connection.SingleConnectionFactory
Create a new SingleConnectionFactory that always returns a single Connection that it will lazily create via the given target ConnectionFactory.
sleepInbetweenRecoveryAttempts() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Sleep according to the specified recovery interval.
SmartConnectionFactory - Interface in org.springframework.jms.connection
Extension of the javax.jms.ConnectionFactory interface, indicating how to release Connections obtained from it.
StandardJmsActivationSpecFactory - Class in org.springframework.jms.listener.endpoint
Standard implementation of the JmsActivationSpecFactory interface.
StandardJmsActivationSpecFactory() - Constructor for class org.springframework.jms.listener.endpoint.StandardJmsActivationSpecFactory
 
start() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Start this container.
start() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Overridden to reset the stop callback, if any.
startSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Start the shared Connection.
startSharedConnection() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
This implementations proceeds even after an exception thrown from Connection.start(), relying on listeners to perform appropriate recovery.
stop() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Stop this container.
stop(Runnable) - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
 
stop(Runnable) - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
Stop this listener container, invoking the specific callback once all listener processing has actually stopped.
stopSharedConnection() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Stop the shared Connection.
stopSharedConnection() - Method in class org.springframework.jms.listener.DefaultMessageListenerContainer
This implementations proceeds even after an exception thrown from Connection.stop(), relying on listeners to perform appropriate recovery after a restart.
SubscriptionNameProvider - Interface in org.springframework.jms.listener
Interface to be implemented by message listener objects that suggest a specific name for a durable subscription that they might be registered with.
SynchedLocalTransactionFailedException - Exception in org.springframework.jms.connection
Exception thrown when a synchronized local transaction failed to complete (after the main transaction has already completed).
SynchedLocalTransactionFailedException(String, JMSException) - Constructor for exception org.springframework.jms.connection.SynchedLocalTransactionFailedException
Create a new SynchedLocalTransactionFailedException.

T

toMessage(Object, Session) - Method in class org.springframework.jms.support.converter.MappingJackson2MessageConverter
 
toMessage(Object, Session) - Method in class org.springframework.jms.support.converter.MappingJacksonMessageConverter
Deprecated.
 
toMessage(Object, Session) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
This implementation marshals the given object to a TextMessage or BytesMessage.
toMessage(Object, Session) - Method in interface org.springframework.jms.support.converter.MessageConverter
Convert a Java object to a JMS Message using the supplied session to create the message object.
toMessage(Object, Session) - Method in class org.springframework.jms.support.converter.SimpleMessageConverter
This implementation creates a TextMessage for a String, a BytesMessage for a byte array, a MapMessage for a Map, and an ObjectMessage for a Serializable object.
TransactionAwareConnectionFactoryProxy - Class in org.springframework.jms.connection
Proxy for a target JMS ConnectionFactory, adding awareness of Spring-managed transactions.
TransactionAwareConnectionFactoryProxy() - Constructor for class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Create a new TransactionAwareConnectionFactoryProxy.
TransactionAwareConnectionFactoryProxy(ConnectionFactory) - Constructor for class org.springframework.jms.connection.TransactionAwareConnectionFactoryProxy
Create a new TransactionAwareConnectionFactoryProxy.
TransactionInProgressException - Exception in org.springframework.jms
Runtime exception mirroring the JMS TransactionInProgressException.
TransactionInProgressException(TransactionInProgressException) - Constructor for exception org.springframework.jms.TransactionInProgressException
 
TransactionRolledBackException - Exception in org.springframework.jms
Runtime exception mirroring the JMS TransactionRolledBackException.
TransactionRolledBackException(TransactionRolledBackException) - Constructor for exception org.springframework.jms.TransactionRolledBackException
 

U

UncategorizedJmsException - Exception in org.springframework.jms
JmsException to be thrown when no other matching subclass found.
UncategorizedJmsException(String) - Constructor for exception org.springframework.jms.UncategorizedJmsException
Constructor that takes a message.
UncategorizedJmsException(String, Throwable) - Constructor for exception org.springframework.jms.UncategorizedJmsException
Constructor that takes a message and a root cause.
UncategorizedJmsException(Throwable) - Constructor for exception org.springframework.jms.UncategorizedJmsException
Constructor that takes a root cause only.
unmarshalFromBytesMessage(BytesMessage, Unmarshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Unmarshal the given BytesMessage into an object.
unmarshalFromMessage(Message, Unmarshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Template method that allows for custom message unmarshalling.
unmarshalFromTextMessage(TextMessage, Unmarshaller) - Method in class org.springframework.jms.support.converter.MarshallingMessageConverter
Unmarshal the given TextMessage into an object.
UserCredentialsConnectionFactoryAdapter - Class in org.springframework.jms.connection
An adapter for a target JMS ConnectionFactory, applying the given user credentials to every standard createConnection() call, that is, implicitly invoking createConnection(username, password) on the target.
UserCredentialsConnectionFactoryAdapter() - Constructor for class org.springframework.jms.connection.UserCredentialsConnectionFactoryAdapter
 

V

validateConfiguration() - Method in class org.springframework.jms.listener.AbstractJmsListeningContainer
Validate the configuration of this container.
validateConfiguration() - Method in class org.springframework.jms.listener.AbstractMessageListenerContainer
 
validateConfiguration() - Method in class org.springframework.jms.listener.SimpleMessageListenerContainer
 
validateDestination(Destination, String, boolean) - Method in class org.springframework.jms.support.destination.JndiDestinationResolver
Validate the given Destination object, checking whether it matches the expected type.
valueOf(String) - Static method in enum org.springframework.jms.support.converter.MessageType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.jms.support.converter.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.

W

writeRemoteInvocationResult(Message, Session, RemoteInvocationResult) - Method in class org.springframework.jms.remoting.JmsInvokerServiceExporter
Send the given RemoteInvocationResult as a JMS message to the originator.
A B C D E F G H I J L M N O P R S T U V W 
Skip navigation links
spring-jms