org.apache.camel.component.jms
Class JmsConfiguration

java.lang.Object
  extended by org.apache.camel.component.jms.JmsConfiguration
All Implemented Interfaces:
Cloneable

@UriParams
public class JmsConfiguration
extends Object
implements Cloneable

Version:

Nested Class Summary
static class JmsConfiguration.CamelJmsTemplate
           
 
Field Summary
static String QUEUE_PREFIX
           
static String TEMP_QUEUE_PREFIX
           
static String TEMP_TOPIC_PREFIX
           
static String TOPIC_PREFIX
           
 
Constructor Summary
JmsConfiguration()
           
JmsConfiguration(javax.jms.ConnectionFactory connectionFactory)
           
 
Method Summary
 org.springframework.jms.listener.AbstractMessageListenerContainer chooseMessageListenerContainerImplementation(JmsEndpoint endpoint)
           
protected  void configuredQoS()
          When one of the QoS properties are configured such as setDeliveryPersistent(boolean), setPriority(int) or setTimeToLive(long) then we should auto default the setting of setExplicitQosEnabled(boolean) if its not been configured yet
 void configureMessageListener(EndpointMessageListener listener)
           
protected  void configureMessageListenerContainer(org.springframework.jms.listener.AbstractMessageListenerContainer container, JmsEndpoint endpoint)
           
 JmsConfiguration copy()
          Returns a copy of this configuration
protected  javax.jms.ConnectionFactory createConnectionFactory()
          Factory method which allows derived classes to customize the lazy creation
static org.springframework.jms.support.destination.DestinationResolver createDestinationResolver(DestinationEndpoint destinationEndpoint)
           
 org.springframework.jms.core.JmsOperations createInOnlyTemplate(JmsEndpoint endpoint, boolean pubSubDomain, String destination)
          Creates a JmsOperations object used for one way messaging
 org.springframework.jms.core.JmsOperations createInOutTemplate(JmsEndpoint endpoint, boolean pubSubDomain, String destination, long requestTimeout)
          Creates a JmsOperations object used for request/response using a request timeout value
protected  javax.jms.ConnectionFactory createListenerConnectionFactory()
          Factory method which allows derived classes to customize the lazy creation
 org.springframework.jms.listener.AbstractMessageListenerContainer createMessageListenerContainer(JmsEndpoint endpoint)
           
protected  javax.jms.ConnectionFactory createTemplateConnectionFactory()
          Factory method which allows derived classes to customize the lazy creation
protected  org.springframework.transaction.PlatformTransactionManager createTransactionManager()
          Factory method which which allows derived classes to customize the lazy transaction manager creation
protected  int defaultCacheLevel(JmsEndpoint endpoint)
          Defaults the JMS cache level if none is explicitly specified.
 int getAcknowledgementMode()
           
 String getAcknowledgementModeName()
           
 int getCacheLevel()
           
 String getCacheLevelName()
           
 String getClientId()
           
 int getConcurrentConsumers()
           
 javax.jms.ConnectionFactory getConnectionFactory()
           
 ConsumerType getConsumerType()
           
 DefaultTaskExecutorType getDefaultTaskExecutorType()
           
 Integer getDeliveryMode()
           
 org.springframework.jms.support.destination.DestinationResolver getDestinationResolver()
           
 String getDurableSubscriptionName()
           
 org.springframework.util.ErrorHandler getErrorHandler()
           
 org.apache.camel.LoggingLevel getErrorHandlerLoggingLevel()
           
 javax.jms.ExceptionListener getExceptionListener()
           
 int getIdleConsumerLimit()
           
 int getIdleTaskExecutionLimit()
           
 JmsKeyFormatStrategy getJmsKeyFormatStrategy()
           
 JmsMessageType getJmsMessageType()
           
 org.springframework.jms.core.JmsOperations getJmsOperations()
           
 javax.jms.ConnectionFactory getListenerConnectionFactory()
           
 int getMaxConcurrentConsumers()
           
 int getMaxMessagesPerTask()
           
 org.springframework.jms.support.converter.MessageConverter getMessageConverter()
           
 MessageListenerContainerFactory getMessageListenerContainerFactory()
           
 org.springframework.jms.core.JmsOperations getMetadataJmsOperations(JmsEndpoint endpoint)
           
 int getPriority()
           
 JmsProviderMetadata getProviderMetadata()
           
 long getReceiveTimeout()
           
 long getRecoveryInterval()
           
 String getReplyTo()
           
 String getReplyToCacheLevelName()
           
 String getReplyToDestinationSelectorName()
           
 ReplyToType getReplyToType()
          Gets the reply to type.
 long getRequestTimeout()
           
 long getRequestTimeoutCheckerInterval()
           
 org.springframework.core.task.TaskExecutor getTaskExecutor()
           
 javax.jms.ConnectionFactory getTemplateConnectionFactory()
           
 long getTimeToLive()
           
 org.springframework.transaction.PlatformTransactionManager getTransactionManager()
           
 String getTransactionName()
           
 int getTransactionTimeout()
           
 boolean isAcceptMessagesWhileStopping()
           
 boolean isAllowNullBody()
           
 boolean isAlwaysCopyMessage()
           
 boolean isAsyncConsumer()
           
 boolean isAsyncStartListener()
           
 boolean isAsyncStopListener()
           
 boolean isAutoStartup()
           
 boolean isDeliveryPersistent()
           
 boolean isDisableReplyTo()
           
 boolean isDisableTimeToLive()
           
 boolean isEagerLoadingOfProperties()
           
 boolean isErrorHandlerLogStackTrace()
           
 boolean isExplicitQosEnabled()
           
 boolean isExposeListenerSession()
           
 boolean isForceSendOriginalMessage()
           
 boolean isIncludeAllJMSXProperties()
           
 boolean isIncludeSentJMSMessageID()
           
 boolean isLazyCreateTransactionManager()
           
 boolean isMapJmsMessage()
           
 boolean isMessageIdEnabled()
           
 boolean isMessageTimestampEnabled()
           
 boolean isPreserveMessageQos()
           
 boolean isPubSubNoLocal()
           
 boolean isReplyToDeliveryPersistent()
           
 boolean isSubscriptionDurable()
          Deprecated. 
 boolean isTestConnectionOnStartup()
           
 boolean isTransacted()
           
 boolean isTransactedInOut()
          Deprecated. 
 boolean isTransferException()
           
 boolean isTransferExchange()
           
 boolean isUseMessageIDAsCorrelationID()
           
 void setAcceptMessagesWhileStopping(boolean acceptMessagesWhileStopping)
           
 void setAcknowledgementMode(int consumerAcknowledgementMode)
           
 void setAcknowledgementModeName(String consumerAcknowledgementMode)
           
 void setAllowNullBody(boolean allowNullBody)
          Whether to allow sending with no doy (eg as null)
 void setAlwaysCopyMessage(boolean alwaysCopyMessage)
           
 void setAsyncConsumer(boolean asyncConsumer)
          Sets whether asynchronous routing is enabled on JmsConsumer.
 void setAsyncStartListener(boolean asyncStartListener)
           
 void setAsyncStopListener(boolean asyncStopListener)
           
 void setAutoStartup(boolean autoStartup)
           
 void setCacheLevel(int cacheLevel)
           
 void setCacheLevelName(String cacheName)
           
 void setClientId(String consumerClientId)
           
 void setConcurrentConsumers(int concurrentConsumers)
           
 void setConnectionFactory(javax.jms.ConnectionFactory connectionFactory)
          Sets the default connection factory to be used if a connection factory is not specified for either setTemplateConnectionFactory(ConnectionFactory) or setListenerConnectionFactory(ConnectionFactory)
 void setConsumerType(ConsumerType consumerType)
           
 void setDefaultTaskExecutorType(DefaultTaskExecutorType defaultTaskExecutorType)
          Indicates what type of TaskExecutor to use by default for JMS consumers.
 void setDeliveryMode(Integer deliveryMode)
           
 void setDeliveryPersistent(boolean deliveryPersistent)
           
 void setDestinationResolver(org.springframework.jms.support.destination.DestinationResolver destinationResolver)
           
 void setDisableReplyTo(boolean disableReplyTo)
          Disables the use of the JMSReplyTo header for consumers so that inbound messages are treated as InOnly rather than InOut requests.
 void setDisableTimeToLive(boolean disableTimeToLive)
           
 void setDurableSubscriptionName(String durableSubscriptionName)
           
 void setEagerLoadingOfProperties(boolean eagerLoadingOfProperties)
          Enables eager loading of JMS properties as soon as a message is loaded which generally is inefficient as the JMS properties may not be required but sometimes can catch early any issues with the underlying JMS provider and the use of JMS properties
 void setErrorHandler(org.springframework.util.ErrorHandler errorHandler)
           
 void setErrorHandlerLoggingLevel(org.apache.camel.LoggingLevel errorHandlerLoggingLevel)
           
 void setErrorHandlerLogStackTrace(boolean errorHandlerLogStackTrace)
           
 void setExceptionListener(javax.jms.ExceptionListener exceptionListener)
           
 void setExplicitQosEnabled(boolean explicitQosEnabled)
           
 void setExposeListenerSession(boolean exposeListenerSession)
           
 void setForceSendOriginalMessage(boolean forceSendOriginalMessage)
           
 void setIdleConsumerLimit(int idleConsumerLimit)
           
 void setIdleTaskExecutionLimit(int idleTaskExecutionLimit)
           
 void setIncludeAllJMSXProperties(boolean includeAllJMSXProperties)
          Whether to include all JMSX properties as Camel headers when binding from JMS to Camel Message.
 void setIncludeSentJMSMessageID(boolean includeSentJMSMessageID)
          Whether to include the actual JMSMessageID set on the Message by the JMS vendor on the Camel Message as a header when sending InOnly messages.
 void setJmsKeyFormatStrategy(JmsKeyFormatStrategy jmsKeyFormatStrategy)
           
 void setJmsMessageType(JmsMessageType jmsMessageType)
           
 void setJmsOperations(org.springframework.jms.core.JmsOperations jmsOperations)
           
 void setLazyCreateTransactionManager(boolean lazyCreating)
           
 void setListenerConnectionFactory(javax.jms.ConnectionFactory listenerConnectionFactory)
          Sets the connection factory to be used for consuming messages
 void setMapJmsMessage(boolean mapJmsMessage)
           
 void setMaxConcurrentConsumers(int maxConcurrentConsumers)
           
 void setMaxMessagesPerTask(int maxMessagesPerTask)
           
 void setMessageConverter(org.springframework.jms.support.converter.MessageConverter messageConverter)
           
 void setMessageIdEnabled(boolean messageIdEnabled)
           
 void setMessageListenerContainerFactory(MessageListenerContainerFactory messageListenerContainerFactory)
           
 void setMessageTimestampEnabled(boolean messageTimestampEnabled)
           
 void setMetadataJmsOperations(org.springframework.jms.core.JmsOperations metadataJmsOperations)
          Sets the JmsOperations used to deduce the JmsProviderMetadata details which if none is customized one is lazily created on demand
 void setPreserveMessageQos(boolean preserveMessageQos)
          Set to true if you want to send message using the QoS settings specified on the message.
 void setPriority(int priority)
           
 void setProviderMetadata(JmsProviderMetadata providerMetadata)
          Allows the provider metadata to be explicitly configured.
 void setPubSubNoLocal(boolean pubSubNoLocal)
           
 void setReceiveTimeout(long receiveTimeout)
           
 void setRecoveryInterval(long recoveryInterval)
           
 void setReplyTo(String replyToDestination)
           
 void setReplyToCacheLevelName(String name)
           
 void setReplyToDeliveryPersistent(boolean replyToDeliveryPersistent)
           
 void setReplyToDestinationSelectorName(String replyToDestinationSelectorName)
           
 void setReplyToType(ReplyToType replyToType)
           
 void setRequestTimeout(long requestTimeout)
          Sets the timeout in milliseconds which requests should timeout after
 void setRequestTimeoutCheckerInterval(long requestTimeoutCheckerInterval)
          Sets the interval in milliseconds how often the request timeout checker should run.
 void setSubscriptionDurable(boolean subscriptionDurable)
          Deprecated. 
 void setTaskExecutor(org.springframework.core.task.TaskExecutor taskExecutor)
           
 void setTemplateConnectionFactory(javax.jms.ConnectionFactory templateConnectionFactory)
          Sets the connection factory to be used for sending messages via the JmsConfiguration.CamelJmsTemplate via createInOnlyTemplate(JmsEndpoint,boolean, String)
 void setTestConnectionOnStartup(boolean testConnectionOnStartup)
           
 void setTimeToLive(long timeToLive)
           
 void setTransacted(boolean consumerTransacted)
           
 void setTransactedInOut(boolean transactedInOut)
          Deprecated. 
 void setTransactionManager(org.springframework.transaction.PlatformTransactionManager transactionManager)
           
 void setTransactionName(String transactionName)
           
 void setTransactionTimeout(int transactionTimeout)
           
 void setTransferException(boolean transferException)
           
 void setTransferExchange(boolean transferExchange)
           
 void setUseMessageIDAsCorrelationID(boolean useMessageIDAsCorrelationID)
           
protected  boolean supportBlobMessage()
          Should get overridden by implementations which support BlobMessages
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Field Detail

QUEUE_PREFIX

public static final String QUEUE_PREFIX
See Also:
Constant Field Values

TOPIC_PREFIX

public static final String TOPIC_PREFIX
See Also:
Constant Field Values

TEMP_QUEUE_PREFIX

public static final String TEMP_QUEUE_PREFIX
See Also:
Constant Field Values

TEMP_TOPIC_PREFIX

public static final String TEMP_TOPIC_PREFIX
See Also:
Constant Field Values
Constructor Detail

JmsConfiguration

public JmsConfiguration()

JmsConfiguration

public JmsConfiguration(javax.jms.ConnectionFactory connectionFactory)
Method Detail

copy

public JmsConfiguration copy()
Returns a copy of this configuration


createInOutTemplate

public org.springframework.jms.core.JmsOperations createInOutTemplate(JmsEndpoint endpoint,
                                                                      boolean pubSubDomain,
                                                                      String destination,
                                                                      long requestTimeout)
Creates a JmsOperations object used for request/response using a request timeout value


createInOnlyTemplate

public org.springframework.jms.core.JmsOperations createInOnlyTemplate(JmsEndpoint endpoint,
                                                                       boolean pubSubDomain,
                                                                       String destination)
Creates a JmsOperations object used for one way messaging


createMessageListenerContainer

public org.springframework.jms.listener.AbstractMessageListenerContainer createMessageListenerContainer(JmsEndpoint endpoint)
                                                                                                 throws Exception
Throws:
Exception

chooseMessageListenerContainerImplementation

public org.springframework.jms.listener.AbstractMessageListenerContainer chooseMessageListenerContainerImplementation(JmsEndpoint endpoint)

getConsumerType

public ConsumerType getConsumerType()

setConsumerType

public void setConsumerType(ConsumerType consumerType)

getConnectionFactory

public javax.jms.ConnectionFactory getConnectionFactory()

setConnectionFactory

public void setConnectionFactory(javax.jms.ConnectionFactory connectionFactory)
Sets the default connection factory to be used if a connection factory is not specified for either setTemplateConnectionFactory(ConnectionFactory) or setListenerConnectionFactory(ConnectionFactory)

Parameters:
connectionFactory - the default connection factory to use

getListenerConnectionFactory

public javax.jms.ConnectionFactory getListenerConnectionFactory()

setListenerConnectionFactory

public void setListenerConnectionFactory(javax.jms.ConnectionFactory listenerConnectionFactory)
Sets the connection factory to be used for consuming messages

Parameters:
listenerConnectionFactory - the connection factory to use for consuming messages

getTemplateConnectionFactory

public javax.jms.ConnectionFactory getTemplateConnectionFactory()

setTemplateConnectionFactory

public void setTemplateConnectionFactory(javax.jms.ConnectionFactory templateConnectionFactory)
Sets the connection factory to be used for sending messages via the JmsConfiguration.CamelJmsTemplate via createInOnlyTemplate(JmsEndpoint,boolean, String)

Parameters:
templateConnectionFactory - the connection factory for sending messages

isAutoStartup

public boolean isAutoStartup()

setAutoStartup

public void setAutoStartup(boolean autoStartup)

isAcceptMessagesWhileStopping

public boolean isAcceptMessagesWhileStopping()

setAcceptMessagesWhileStopping

public void setAcceptMessagesWhileStopping(boolean acceptMessagesWhileStopping)

getClientId

public String getClientId()

setClientId

public void setClientId(String consumerClientId)

getDurableSubscriptionName

public String getDurableSubscriptionName()

setDurableSubscriptionName

public void setDurableSubscriptionName(String durableSubscriptionName)

getExceptionListener

public javax.jms.ExceptionListener getExceptionListener()

setExceptionListener

public void setExceptionListener(javax.jms.ExceptionListener exceptionListener)

setErrorHandler

public void setErrorHandler(org.springframework.util.ErrorHandler errorHandler)

getErrorHandler

public org.springframework.util.ErrorHandler getErrorHandler()

getErrorHandlerLoggingLevel

public org.apache.camel.LoggingLevel getErrorHandlerLoggingLevel()

setErrorHandlerLoggingLevel

public void setErrorHandlerLoggingLevel(org.apache.camel.LoggingLevel errorHandlerLoggingLevel)

isErrorHandlerLogStackTrace

public boolean isErrorHandlerLogStackTrace()

setErrorHandlerLogStackTrace

public void setErrorHandlerLogStackTrace(boolean errorHandlerLogStackTrace)

isSubscriptionDurable

@Deprecated
public boolean isSubscriptionDurable()
Deprecated. 


setSubscriptionDurable

@Deprecated
public void setSubscriptionDurable(boolean subscriptionDurable)
Deprecated. 


getAcknowledgementModeName

public String getAcknowledgementModeName()

setAcknowledgementModeName

public void setAcknowledgementModeName(String consumerAcknowledgementMode)

isExposeListenerSession

public boolean isExposeListenerSession()

setExposeListenerSession

public void setExposeListenerSession(boolean exposeListenerSession)

getTaskExecutor

public org.springframework.core.task.TaskExecutor getTaskExecutor()

setTaskExecutor

public void setTaskExecutor(org.springframework.core.task.TaskExecutor taskExecutor)

isPubSubNoLocal

public boolean isPubSubNoLocal()

setPubSubNoLocal

public void setPubSubNoLocal(boolean pubSubNoLocal)

getConcurrentConsumers

public int getConcurrentConsumers()

setConcurrentConsumers

public void setConcurrentConsumers(int concurrentConsumers)

getMaxMessagesPerTask

public int getMaxMessagesPerTask()

setMaxMessagesPerTask

public void setMaxMessagesPerTask(int maxMessagesPerTask)

getCacheLevel

public int getCacheLevel()

setCacheLevel

public void setCacheLevel(int cacheLevel)

getCacheLevelName

public String getCacheLevelName()

setCacheLevelName

public void setCacheLevelName(String cacheName)

getRecoveryInterval

public long getRecoveryInterval()

setRecoveryInterval

public void setRecoveryInterval(long recoveryInterval)

getReceiveTimeout

public long getReceiveTimeout()

setReceiveTimeout

public void setReceiveTimeout(long receiveTimeout)

getTransactionManager

public org.springframework.transaction.PlatformTransactionManager getTransactionManager()

setTransactionManager

public void setTransactionManager(org.springframework.transaction.PlatformTransactionManager transactionManager)

getTransactionName

public String getTransactionName()

setTransactionName

public void setTransactionName(String transactionName)

getTransactionTimeout

public int getTransactionTimeout()

setTransactionTimeout

public void setTransactionTimeout(int transactionTimeout)

getIdleTaskExecutionLimit

public int getIdleTaskExecutionLimit()

setIdleTaskExecutionLimit

public void setIdleTaskExecutionLimit(int idleTaskExecutionLimit)

getIdleConsumerLimit

public int getIdleConsumerLimit()

setIdleConsumerLimit

public void setIdleConsumerLimit(int idleConsumerLimit)

getMaxConcurrentConsumers

public int getMaxConcurrentConsumers()

setMaxConcurrentConsumers

public void setMaxConcurrentConsumers(int maxConcurrentConsumers)

isExplicitQosEnabled

public boolean isExplicitQosEnabled()

setExplicitQosEnabled

public void setExplicitQosEnabled(boolean explicitQosEnabled)

isDeliveryPersistent

public boolean isDeliveryPersistent()

setDeliveryPersistent

public void setDeliveryPersistent(boolean deliveryPersistent)

getDeliveryMode

public Integer getDeliveryMode()

setDeliveryMode

public void setDeliveryMode(Integer deliveryMode)

isReplyToDeliveryPersistent

public boolean isReplyToDeliveryPersistent()

setReplyToDeliveryPersistent

public void setReplyToDeliveryPersistent(boolean replyToDeliveryPersistent)

getTimeToLive

public long getTimeToLive()

setTimeToLive

public void setTimeToLive(long timeToLive)

getMessageConverter

public org.springframework.jms.support.converter.MessageConverter getMessageConverter()

setMessageConverter

public void setMessageConverter(org.springframework.jms.support.converter.MessageConverter messageConverter)

isMapJmsMessage

public boolean isMapJmsMessage()

setMapJmsMessage

public void setMapJmsMessage(boolean mapJmsMessage)

isMessageIdEnabled

public boolean isMessageIdEnabled()

setMessageIdEnabled

public void setMessageIdEnabled(boolean messageIdEnabled)

isMessageTimestampEnabled

public boolean isMessageTimestampEnabled()

setMessageTimestampEnabled

public void setMessageTimestampEnabled(boolean messageTimestampEnabled)

getPriority

public int getPriority()

setPriority

public void setPriority(int priority)

getAcknowledgementMode

public int getAcknowledgementMode()

setAcknowledgementMode

public void setAcknowledgementMode(int consumerAcknowledgementMode)

isTransacted

public boolean isTransacted()

setTransacted

public void setTransacted(boolean consumerTransacted)

isTransactedInOut

@Deprecated
public boolean isTransactedInOut()
Deprecated. 

Should InOut operations (request reply) default to using transacted mode?

By default this is false as you need to commit the outgoing request before you can consume the input


setTransactedInOut

@Deprecated
public void setTransactedInOut(boolean transactedInOut)
Deprecated. 


isLazyCreateTransactionManager

public boolean isLazyCreateTransactionManager()

setLazyCreateTransactionManager

public void setLazyCreateTransactionManager(boolean lazyCreating)

isEagerLoadingOfProperties

public boolean isEagerLoadingOfProperties()

setEagerLoadingOfProperties

public void setEagerLoadingOfProperties(boolean eagerLoadingOfProperties)
Enables eager loading of JMS properties as soon as a message is loaded which generally is inefficient as the JMS properties may not be required but sometimes can catch early any issues with the underlying JMS provider and the use of JMS properties

Parameters:
eagerLoadingOfProperties - whether or not to enable eager loading of JMS properties on inbound messages

isDisableReplyTo

public boolean isDisableReplyTo()

setDisableReplyTo

public void setDisableReplyTo(boolean disableReplyTo)
Disables the use of the JMSReplyTo header for consumers so that inbound messages are treated as InOnly rather than InOut requests.

Parameters:
disableReplyTo - whether or not to disable the use of JMSReplyTo header indicating an InOut

setPreserveMessageQos

public void setPreserveMessageQos(boolean preserveMessageQos)
Set to true if you want to send message using the QoS settings specified on the message. Normally the QoS settings used are the one configured on this Object.


getJmsOperations

public org.springframework.jms.core.JmsOperations getJmsOperations()

setJmsOperations

public void setJmsOperations(org.springframework.jms.core.JmsOperations jmsOperations)

getDestinationResolver

public org.springframework.jms.support.destination.DestinationResolver getDestinationResolver()

setDestinationResolver

public void setDestinationResolver(org.springframework.jms.support.destination.DestinationResolver destinationResolver)

getProviderMetadata

public JmsProviderMetadata getProviderMetadata()

setProviderMetadata

public void setProviderMetadata(JmsProviderMetadata providerMetadata)
Allows the provider metadata to be explicitly configured. Typically this is not required and Camel will auto-detect the provider metadata from the underlying provider.


getMetadataJmsOperations

public org.springframework.jms.core.JmsOperations getMetadataJmsOperations(JmsEndpoint endpoint)

setMetadataJmsOperations

public void setMetadataJmsOperations(org.springframework.jms.core.JmsOperations metadataJmsOperations)
Sets the JmsOperations used to deduce the JmsProviderMetadata details which if none is customized one is lazily created on demand


createDestinationResolver

public static org.springframework.jms.support.destination.DestinationResolver createDestinationResolver(DestinationEndpoint destinationEndpoint)

configureMessageListenerContainer

protected void configureMessageListenerContainer(org.springframework.jms.listener.AbstractMessageListenerContainer container,
                                                 JmsEndpoint endpoint)
                                          throws Exception
Throws:
Exception

configureMessageListener

public void configureMessageListener(EndpointMessageListener listener)

defaultCacheLevel

protected int defaultCacheLevel(JmsEndpoint endpoint)
Defaults the JMS cache level if none is explicitly specified.

Will return CACHE_AUTO which will pickup and use CACHE_NONE if transacted has been enabled, otherwise it will use CACHE_CONSUMER which is the most efficient.

Parameters:
endpoint - the endpoint
Returns:
the cache level

createConnectionFactory

protected javax.jms.ConnectionFactory createConnectionFactory()
Factory method which allows derived classes to customize the lazy creation


createListenerConnectionFactory

protected javax.jms.ConnectionFactory createListenerConnectionFactory()
Factory method which allows derived classes to customize the lazy creation


createTemplateConnectionFactory

protected javax.jms.ConnectionFactory createTemplateConnectionFactory()
Factory method which allows derived classes to customize the lazy creation


createTransactionManager

protected org.springframework.transaction.PlatformTransactionManager createTransactionManager()
Factory method which which allows derived classes to customize the lazy transaction manager creation


isPreserveMessageQos

public boolean isPreserveMessageQos()

configuredQoS

protected void configuredQoS()
When one of the QoS properties are configured such as setDeliveryPersistent(boolean), setPriority(int) or setTimeToLive(long) then we should auto default the setting of setExplicitQosEnabled(boolean) if its not been configured yet


isAlwaysCopyMessage

public boolean isAlwaysCopyMessage()

setAlwaysCopyMessage

public void setAlwaysCopyMessage(boolean alwaysCopyMessage)

isUseMessageIDAsCorrelationID

public boolean isUseMessageIDAsCorrelationID()

setUseMessageIDAsCorrelationID

public void setUseMessageIDAsCorrelationID(boolean useMessageIDAsCorrelationID)

getRequestTimeout

public long getRequestTimeout()

setRequestTimeout

public void setRequestTimeout(long requestTimeout)
Sets the timeout in milliseconds which requests should timeout after


getRequestTimeoutCheckerInterval

public long getRequestTimeoutCheckerInterval()

setRequestTimeoutCheckerInterval

public void setRequestTimeoutCheckerInterval(long requestTimeoutCheckerInterval)
Sets the interval in milliseconds how often the request timeout checker should run.


getReplyTo

public String getReplyTo()

setReplyTo

public void setReplyTo(String replyToDestination)

getReplyToDestinationSelectorName

public String getReplyToDestinationSelectorName()

setReplyToDestinationSelectorName

public void setReplyToDestinationSelectorName(String replyToDestinationSelectorName)

getJmsMessageType

public JmsMessageType getJmsMessageType()

setJmsMessageType

public void setJmsMessageType(JmsMessageType jmsMessageType)

supportBlobMessage

protected boolean supportBlobMessage()
Should get overridden by implementations which support BlobMessages

Returns:
false

getJmsKeyFormatStrategy

public JmsKeyFormatStrategy getJmsKeyFormatStrategy()

setJmsKeyFormatStrategy

public void setJmsKeyFormatStrategy(JmsKeyFormatStrategy jmsKeyFormatStrategy)

isTransferExchange

public boolean isTransferExchange()

setTransferExchange

public void setTransferExchange(boolean transferExchange)

isTransferException

public boolean isTransferException()

setTransferException

public void setTransferException(boolean transferException)

isAsyncStartListener

public boolean isAsyncStartListener()

setAsyncStartListener

public void setAsyncStartListener(boolean asyncStartListener)

isAsyncStopListener

public boolean isAsyncStopListener()

setAsyncStopListener

public void setAsyncStopListener(boolean asyncStopListener)

isTestConnectionOnStartup

public boolean isTestConnectionOnStartup()

setTestConnectionOnStartup

public void setTestConnectionOnStartup(boolean testConnectionOnStartup)

setForceSendOriginalMessage

public void setForceSendOriginalMessage(boolean forceSendOriginalMessage)

isForceSendOriginalMessage

public boolean isForceSendOriginalMessage()

isDisableTimeToLive

public boolean isDisableTimeToLive()

setDisableTimeToLive

public void setDisableTimeToLive(boolean disableTimeToLive)

getReplyToType

public ReplyToType getReplyToType()
Gets the reply to type.

Will only return a value if this option has been explicit configured.

Returns:
the reply type if configured, otherwise null

setReplyToType

public void setReplyToType(ReplyToType replyToType)

isAsyncConsumer

public boolean isAsyncConsumer()

setAsyncConsumer

public void setAsyncConsumer(boolean asyncConsumer)
Sets whether asynchronous routing is enabled on JmsConsumer.

By default this is false. If configured as true then the JmsConsumer will process the Exchange asynchronous.


setReplyToCacheLevelName

public void setReplyToCacheLevelName(String name)

getReplyToCacheLevelName

public String getReplyToCacheLevelName()

isAllowNullBody

public boolean isAllowNullBody()

setAllowNullBody

public void setAllowNullBody(boolean allowNullBody)
Whether to allow sending with no doy (eg as null)


getMessageListenerContainerFactory

public MessageListenerContainerFactory getMessageListenerContainerFactory()

setMessageListenerContainerFactory

public void setMessageListenerContainerFactory(MessageListenerContainerFactory messageListenerContainerFactory)

isIncludeSentJMSMessageID

public boolean isIncludeSentJMSMessageID()

setIncludeSentJMSMessageID

public void setIncludeSentJMSMessageID(boolean includeSentJMSMessageID)
Whether to include the actual JMSMessageID set on the Message by the JMS vendor on the Camel Message as a header when sending InOnly messages.

Can be enable to gather the actual JMSMessageID for InOnly messages, which allows to access the message id, which can be used for logging and tracing purposes.

This option is default false.


getDefaultTaskExecutorType

public DefaultTaskExecutorType getDefaultTaskExecutorType()

setDefaultTaskExecutorType

public void setDefaultTaskExecutorType(DefaultTaskExecutorType defaultTaskExecutorType)
Indicates what type of TaskExecutor to use by default for JMS consumers. Refer to the documentation of DefaultTaskExecutorType for available options.


isIncludeAllJMSXProperties

public boolean isIncludeAllJMSXProperties()

setIncludeAllJMSXProperties

public void setIncludeAllJMSXProperties(boolean includeAllJMSXProperties)
Whether to include all JMSX properties as Camel headers when binding from JMS to Camel Message.

By default a number of properties is excluded accordingly to the table of JMS properties in the JMS 1.1 spec, on page 39.



Apache Camel