A B C D E F G H I J K L M N O P Q R S T V 

A

AbstractMessageHandler - Class in org.apache.camel.component.sjms.consumer
Abstract MessageListener
AbstractMessageHandler(Endpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
AbstractMessageHandler(Endpoint, ExecutorService, Synchronization) - Constructor for class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
addTask(TimerTask, long) - Method in class org.apache.camel.component.sjms.taskmanager.TimedTaskManager
 

B

BatchMessage<T> - Class in org.apache.camel.component.sjms
A List of these objects can be used to batch a collection of bodies and header pairs in one exchange.
BatchMessage(T, Map<String, Object>) - Constructor for class org.apache.camel.component.sjms.BatchMessage
 
BatchTransactionCommitStrategy - Class in org.apache.camel.component.sjms.tx
Provides a thread safe counter to track the number of Exchange objects that have been been processed.
BatchTransactionCommitStrategy(int) - Constructor for class org.apache.camel.component.sjms.tx.BatchTransactionCommitStrategy
 
borrowConnection() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
borrowConnection() - Method in interface org.apache.camel.component.sjms.jms.ConnectionResource
Borrows a Connection from the connection pool.

C

cancel() - Method in class org.apache.camel.component.sjms.tx.SessionBatchTransactionSynchronization.TimeoutTask
 
cancelTasks() - Method in class org.apache.camel.component.sjms.taskmanager.TimedTaskManager
 
close() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
Method will be called to
close() - Method in class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
close() - Method in class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
commit(Exchange) - Method in interface org.apache.camel.component.sjms.TransactionCommitStrategy
Should returns true to allow the commit to proceed.
commit(Exchange) - Method in class org.apache.camel.component.sjms.tx.BatchTransactionCommitStrategy
 
commit(Exchange) - Method in class org.apache.camel.component.sjms.tx.DefaultTransactionCommitStrategy
 
ConnectionFactoryResource - Class in org.apache.camel.component.sjms.jms
The default ConnectionResource implementation for the SJMSComponent.
ConnectionFactoryResource() - Constructor for class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
Default Constructor
ConnectionFactoryResource(int, ConnectionFactory) - Constructor for class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
ConnectionFactoryResource(int, ConnectionFactory, String, String) - Constructor for class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
ConnectionFactoryResource(int, ConnectionFactory, String, String, String) - Constructor for class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
ConnectionFactoryResource(int, ConnectionFactory, String, String, String, long) - Constructor for class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
ConnectionResource - Interface in org.apache.camel.component.sjms.jms
The ConnectionResource is the contract used to provide Connection pools to the SJMS component.
consumers - Variable in class org.apache.camel.component.sjms.SjmsConsumer
 
createConsumer(Processor) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createDestination(Session, String, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
createExchange(Message, Endpoint) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
 
createMessage(Session, Object, Map<String, Object>, KeyFormatStrategy) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
 
createMessage(Exchange, Session, KeyFormatStrategy) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
 
createMessageConsumer(Session, String, String, boolean, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageConsumer(Session, String, String, boolean, String, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageConsumer(Session, Destination, String, boolean, String, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageHandler(Session) - Method in class org.apache.camel.component.sjms.SjmsConsumer
Helper factory method used to create a MessageListener based on the MEP
createMessageProducer(Session, String, boolean, boolean, long) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createProducer() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createQueue(Session, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createQueueConsumer(Session, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createQueueConsumer(Session, String, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createQueueProducer(Session, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createTemporaryDestination(Session, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createTemporaryMessageConsumer(Session, String, boolean, String, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createTopic(Session, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createTopicConsumer(Session, String, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createTopicProducer(Session, String) - Static method in class org.apache.camel.component.sjms.jms.JmsObjectFactory
 

D

decodeKey(String) - Method in class org.apache.camel.component.sjms.jms.DefaultJmsKeyFormatStrategy
 
decodeKey(String) - Method in interface org.apache.camel.component.sjms.jms.KeyFormatStrategy
Decodes the key after its received from a Message message.
DefaultJmsKeyFormatStrategy - Class in org.apache.camel.component.sjms.jms
Default strategy that handles dots and hyphens.
DefaultJmsKeyFormatStrategy() - Constructor for class org.apache.camel.component.sjms.jms.DefaultJmsKeyFormatStrategy
 
DefaultTransactionCommitStrategy - Class in org.apache.camel.component.sjms.tx
The default commit strategy for all transaction.
DefaultTransactionCommitStrategy() - Constructor for class org.apache.camel.component.sjms.tx.DefaultTransactionCommitStrategy
 
destroyObject(Connection) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
destroyObject(MessageConsumerResources) - Method in class org.apache.camel.component.sjms.producer.InOutProducer.MessageConsumerResourcesFactory
 
destroyObject(MessageConsumerResources) - Method in class org.apache.camel.component.sjms.SjmsConsumer.MessageConsumerResourcesFactory
Cleans up the MessageConsumerResources.
destroyObject(MessageProducerResources) - Method in class org.apache.camel.component.sjms.SjmsProducer.MessageProducerResourcesFactory
 
discoverJmsMessageType(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
 
discoverMessgeTypeFromPayload(Object) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
 
doCreateProducerModel() - Method in class org.apache.camel.component.sjms.producer.InOnlyProducer
 
doCreateProducerModel() - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
doCreateProducerModel() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
done(boolean) - Method in class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler.NoOpAsyncCallback
 
done(boolean) - Method in class org.apache.camel.component.sjms.consumer.InOutMessageHandler.MessageHanderAsyncCallback
 
doShutdown() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
doStart() - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
doStart() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
doStart() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
doStart() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
doStart() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
doStop() - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
doStop() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
doStop() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
doStop() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
doStop() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
drainPool() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 

E

encodeKey(String) - Method in class org.apache.camel.component.sjms.jms.DefaultJmsKeyFormatStrategy
 
encodeKey(String) - Method in interface org.apache.camel.component.sjms.jms.KeyFormatStrategy
Encodes the key before its sent as a Message message.
equals(Object) - Method in class org.apache.camel.component.sjms.BatchMessage
 

F

fillPool() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 

G

getAcknowledgementMode() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
getAcknowledgementMode() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the configured acknowledgementMode.
getAcknowledgeMode() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the acknowledgment mode for this instance of DestinationProducer.
getAsyncStartStopExecutorService() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getClientId() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getCommitStrategy() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
getCommitStrategy() - Method in class org.apache.camel.component.sjms.MessageProducerResources
Gets the TransactionCommitStrategy value of commitStrategy for this instance of SjmsProducer.MessageProducerResources.
getCommitStrategy() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets commitStrategy for this instance of SjmsProducer.
getComponent() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getConnectionCount() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.SjmsComponent
Gets the ConnectionFactory value of connectionFactory for this instance of SjmsComponent.
getConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
getConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
getConsumerCount() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Returns the number of consumer listeners.
getConsumerCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the number of consumer listeners for this endpoint.
getConsumerCount() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets consumerCount for this instance of SjmsProducer.
getConsumers() - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
getDestinationName() - Method in class org.apache.camel.component.sjms.SjmsConsumer
The destination name for this consumer.
getDestinationName() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getDestinationName() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the destinationName for this instance of DestinationProducer.
getDurableSubscriptionId() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Gets the durable subscription Id.
getDurableSubscriptionId() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Gets the durable subscription Id.
getEndpoint() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
getEndpoint() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
getEndpoint() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
getExecutor() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the executor for this instance of SjmsProducer.
getHeaderFilterStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getHeaders() - Method in class org.apache.camel.component.sjms.BatchMessage
 
getJmsKeyFormatStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getJMSRedelivered(Message) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Gets the JMSRedelivered from the message.
getJMSReplyTo(Message) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Gets the JMSReplyTo from the message.
getJMSType(Message) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Gets the JMSType from the message.
getKeyFormatStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getMessageConsumer() - Method in class org.apache.camel.component.sjms.MessageConsumerResources
 
getMessageProducer() - Method in class org.apache.camel.component.sjms.MessageProducerResources
Gets the QueueSender value of queueSender for this instance of MessageProducerResources.
getMessageSelector() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Gets the JMS Message selector syntax.
getMessageSelector() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the JMS Message selector syntax used to refine the messages being consumed.
getNamedReplyTo() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the reply to destination name used for InOut producer endpoints.
getNamedReplyTo() - Method in class org.apache.camel.component.sjms.SjmsProducer
Returns the named reply to value for this producer
getPassword() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getPayload() - Method in class org.apache.camel.component.sjms.BatchMessage
 
getProcessor() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
getProducerCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the number of consumer listeners for this endpoint.
getProducerCount() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the producerCount for this instance of SjmsProducer.
getProducers() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the MessageProducerPool value of producers for this instance of SjmsProducer.
getReplyTo() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the replyTo for this instance of DestinationProducer.
getReplyToDestination() - Method in class org.apache.camel.component.sjms.MessageConsumerResources
 
getResponseTimeOut() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the InOut response timeout.
getResponseTimeOut() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets responseTimeOut for this instance of SjmsProducer.
getSession() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
getSession() - Method in class org.apache.camel.component.sjms.MessageConsumerResources
 
getSession() - Method in class org.apache.camel.component.sjms.MessageProducerResources
Gets the Session value of session for this instance of MessageProducerResources.
getSessionCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Deprecated.
getSjmsEndpoint() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
getSjmsHeaderFilterStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getTimedTaskManager() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getTransactionBatchCount() - Method in class org.apache.camel.component.sjms.SjmsConsumer
If transacted, returns the nubmer of messages to be processed before committing the transaction.
getTransactionBatchCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
If transacted, returns the nubmer of messages to be processed before committing the transaction.
getTransactionBatchTimeout() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Returns the timeout value for batch transactions.
getTransactionBatchTimeout() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the timeout value for batch transactions.
getTransactionCommitStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
Gets the TransactionCommitStrategy value of transactionCommitStrategy for this instance of SjmsComponent.
getTransactionCommitStrategy() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Gets the commit strategy.
getTransactionCommitStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Gets the commit strategy.
getTtl() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Returns the Time To Live set on this endpoint.
getTtl() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the ttl for this instance of SjmsProducer.
getUsername() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 

H

handleMessage(Exchange) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
handleMessage(Exchange) - Method in class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
handleMessage(Exchange) - Method in class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
hashCode() - Method in class org.apache.camel.component.sjms.BatchMessage
 
hasProperty(Message, String) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Tests whether a given property with the name exists

I

IllegalHeaderException - Exception in org.apache.camel.component.sjms.jms
IllegalHeaderException is thrown if a header is detected that doesn't meet the JMS standard.
IllegalHeaderException() - Constructor for exception org.apache.camel.component.sjms.jms.IllegalHeaderException
 
IllegalHeaderException(String, Throwable) - Constructor for exception org.apache.camel.component.sjms.jms.IllegalHeaderException
 
IllegalHeaderException(String) - Constructor for exception org.apache.camel.component.sjms.jms.IllegalHeaderException
 
IllegalHeaderException(Throwable) - Constructor for exception org.apache.camel.component.sjms.jms.IllegalHeaderException
 
initialize() - Method in class org.apache.camel.component.sjms.SjmsHeaderFilterStrategy
 
InOnlyMessageHandler - Class in org.apache.camel.component.sjms.consumer
InOnlyMessageHandler(Endpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
InOnlyMessageHandler(Endpoint, ExecutorService, Synchronization) - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
InOnlyMessageHandler.NoOpAsyncCallback - Class in org.apache.camel.component.sjms.consumer
 
InOnlyMessageHandler.NoOpAsyncCallback() - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler.NoOpAsyncCallback
 
InOnlyProducer - Class in org.apache.camel.component.sjms.producer
A Camel Producer that provides the InOnly Exchange pattern..
InOnlyProducer(Endpoint) - Constructor for class org.apache.camel.component.sjms.producer.InOnlyProducer
 
InOutMessageHandler - Class in org.apache.camel.component.sjms.consumer
cache manager to store and purge unused cashed producers or we will have a memory leak
InOutMessageHandler(Endpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
InOutMessageHandler(Endpoint, ExecutorService, Synchronization) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
InOutMessageHandler.MessageHanderAsyncCallback - Class in org.apache.camel.component.sjms.consumer
 
InOutMessageHandler.MessageHanderAsyncCallback(Exchange, MessageProducer) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler.MessageHanderAsyncCallback
 
InOutProducer - Class in org.apache.camel.component.sjms.producer
A Camel Producer that provides the InOut Exchange pattern.
InOutProducer(SjmsEndpoint) - Constructor for class org.apache.camel.component.sjms.producer.InOutProducer
 
InOutProducer.InternalTempDestinationListener - Class in org.apache.camel.component.sjms.producer
 
InOutProducer.InternalTempDestinationListener(Exchanger<Object>) - Constructor for class org.apache.camel.component.sjms.producer.InOutProducer.InternalTempDestinationListener
 
InOutProducer.MessageConsumerResourcesFactory - Class in org.apache.camel.component.sjms.producer
A pool of MessageConsumerResource objects that are the reply consumers.
InOutProducer.MessageConsumerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.producer.InOutProducer.MessageConsumerResourcesFactory
 
intValue() - Method in enum org.apache.camel.component.sjms.jms.SessionAcknowledgementType
 
isAsyncStartListener() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isAsyncStopListener() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isEndpointTransacted() - Method in class org.apache.camel.component.sjms.SjmsProducer
Test to determine if this endpoint should use a JMS Transaction.
isMultipleConsumersSupported() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isPersistent() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Use to determine if the enpoint has message persistence enabled or disabled.
isPersistent() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the boolean value of persistent for this instance of SjmsProducer.
isPrefillPool() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isSingleton() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isSynchronous() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
isSynchronous() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Use to determine whether or not to process exchanges synchronously.
isSynchronous() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Use to determine whether or not to process exchanges synchronously.
isSynchronous() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the synchronous value for this instance of DestinationProducer.
isTopic() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
isTopic() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Flag set by the endpoint used by consumers and producers to determine if the consumer is a JMS Topic.
isTopic() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Flag set by the endpoint used by consumers and producers to determine if the endpoint is a JMS Topic.
isTopic() - Method in class org.apache.camel.component.sjms.SjmsProducer
Test to verify if this endpoint is a JMS Topic or Queue.
isTransacted() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
isTransacted() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Use to determine if transactions are enabled or disabled.
isTransacted() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Use to determine if transactions are enabled or disabled.

J

JMS_CORRELATION_ID - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set by the publishing Client
JMS_DELIVERY_MODE - Static variable in class org.apache.camel.component.sjms.jms.JmsConstants
 
JMS_DELIVERY_MODE - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_DESTINATION - Static variable in class org.apache.camel.component.sjms.jms.JmsConstants
 
JMS_DESTINATION - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_DESTINATION_NAME - Static variable in class org.apache.camel.component.sjms.jms.JmsConstants
 
JMS_EXPIRATION - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_MESSAGE_ID - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_MESSAGE_TYPE - Static variable in class org.apache.camel.component.sjms.jms.JmsConstants
 
JMS_MESSAGE_TYPE - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 
JMS_PRIORITY - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_REDELIVERED - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
A redelivery flag set by the JMS provider
JMS_REPLY_TO - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
The JMS Reply To Destination set by the publishing Client
JMS_TIMESTAMP - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set on the send or publish event
JMS_TYPE - Static variable in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Set by the publishing Client
JmsConstants - Class in org.apache.camel.component.sjms.jms
JMS constants
JmsMessageHeaderType - Enum in org.apache.camel.component.sjms.jms
 
JmsMessageHelper - Class in org.apache.camel.component.sjms.jms
Utility class for Message.
JmsMessageType - Enum in org.apache.camel.component.sjms.jms
Enum for different Message types.
JmsObjectFactory - Class in org.apache.camel.component.sjms.jms
 

K

KeyFormatStrategy - Interface in org.apache.camel.component.sjms.jms
Strategy for applying encoding and decoding of JMS headers so they apply to the JMS spec.

L

log - Variable in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
logger - Variable in class org.apache.camel.component.sjms.SjmsEndpoint
 

M

makeObject() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
makeObject() - Method in class org.apache.camel.component.sjms.producer.InOutProducer.MessageConsumerResourcesFactory
 
makeObject() - Method in class org.apache.camel.component.sjms.SjmsConsumer.MessageConsumerResourcesFactory
Creates a new MessageConsumerResources instance.
makeObject() - Method in class org.apache.camel.component.sjms.SjmsProducer.MessageProducerResourcesFactory
 
MessageConsumerResources - Class in org.apache.camel.component.sjms
 
MessageConsumerResources(MessageConsumer) - Constructor for class org.apache.camel.component.sjms.MessageConsumerResources
 
MessageConsumerResources(Session, MessageConsumer) - Constructor for class org.apache.camel.component.sjms.MessageConsumerResources
 
MessageConsumerResources(Session, MessageConsumer, Destination) - Constructor for class org.apache.camel.component.sjms.MessageConsumerResources
 
MessageProducerResources - Class in org.apache.camel.component.sjms
The MessageProducer resources for all SjmsProducer classes.
MessageProducerResources(Session, MessageProducer) - Constructor for class org.apache.camel.component.sjms.MessageProducerResources
 
MessageProducerResources(Session, MessageProducer, TransactionCommitStrategy) - Constructor for class org.apache.camel.component.sjms.MessageProducerResources
 

N

normalizeDestinationName(String) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Normalizes the destination name, by removing any leading queue or topic prefixes.

O

onComplete(Exchange) - Method in class org.apache.camel.component.sjms.tx.SessionBatchTransactionSynchronization
 
onComplete(Exchange) - Method in class org.apache.camel.component.sjms.tx.SessionTransactionSynchronization
 
onFailure(Exchange) - Method in class org.apache.camel.component.sjms.tx.SessionBatchTransactionSynchronization
 
onFailure(Exchange) - Method in class org.apache.camel.component.sjms.tx.SessionTransactionSynchronization
 
onMessage(Message) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
onMessage(Message) - Method in class org.apache.camel.component.sjms.producer.InOutProducer.InternalTempDestinationListener
 
org.apache.camel.component.sjms - package org.apache.camel.component.sjms
 
org.apache.camel.component.sjms.consumer - package org.apache.camel.component.sjms.consumer
 
org.apache.camel.component.sjms.jms - package org.apache.camel.component.sjms.jms
 
org.apache.camel.component.sjms.producer - package org.apache.camel.component.sjms.producer
 
org.apache.camel.component.sjms.taskmanager - package org.apache.camel.component.sjms.taskmanager
 
org.apache.camel.component.sjms.tx - package org.apache.camel.component.sjms.tx
 
ORIGINAL_MESSAGE - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 

P

populateExchange(Message, Exchange, boolean) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.sjms.SjmsProducer
 

Q

QUEUE_PREFIX - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 

R

removeJmsProperty(Message, String) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Removes the property from the JMS message.
reset() - Method in class org.apache.camel.component.sjms.tx.BatchTransactionCommitStrategy
 
returnConnection(Connection) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
returnConnection(Connection) - Method in interface org.apache.camel.component.sjms.jms.ConnectionResource
Returns the Connection to the connection pool.
rollback(Exchange) - Method in interface org.apache.camel.component.sjms.TransactionCommitStrategy
Should returns true to allow the commit to proceed.
rollback(Exchange) - Method in class org.apache.camel.component.sjms.tx.BatchTransactionCommitStrategy
 
rollback(Exchange) - Method in class org.apache.camel.component.sjms.tx.DefaultTransactionCommitStrategy
 
run() - Method in class org.apache.camel.component.sjms.tx.SessionBatchTransactionSynchronization.TimeoutTask
When the timer executes, either commits or rolls back the session transaction.

S

sendMessage(Exchange, AsyncCallback, MessageProducerResources) - Method in class org.apache.camel.component.sjms.producer.InOnlyProducer
 
sendMessage(Exchange, AsyncCallback, MessageProducerResources) - Method in class org.apache.camel.component.sjms.producer.InOutProducer
TODO time out is actually double as it waits for the producer and then waits for the response.
sendMessage(Exchange, AsyncCallback, MessageProducerResources) - Method in class org.apache.camel.component.sjms.SjmsProducer
 
SessionAcknowledgementType - Enum in org.apache.camel.component.sjms.jms
Session acknowledge enum keys
SessionBatchTransactionSynchronization - Class in org.apache.camel.component.sjms.tx
SessionTransactionSynchronization is called at the completion of each Exchange.
SessionBatchTransactionSynchronization(TimedTaskManager, Session, TransactionCommitStrategy, long) - Constructor for class org.apache.camel.component.sjms.tx.SessionBatchTransactionSynchronization
 
SessionBatchTransactionSynchronization.TimeoutTask - Class in org.apache.camel.component.sjms.tx
 
SessionTransactionSynchronization - Class in org.apache.camel.component.sjms.tx
SessionTransactionSynchronization is called at the completion of each org.apache.camel.Exhcnage.
SessionTransactionSynchronization(Session, TransactionCommitStrategy) - Constructor for class org.apache.camel.component.sjms.tx.SessionTransactionSynchronization
 
setAcknowledgementMode(SessionAcknowledgementType) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the acknowledgementMode configured on this endpoint.
setAsyncStartListener(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
setAsyncStopListener(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
setClientId(String) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setConnectionCount(Integer) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.SjmsComponent
Sets the ConnectionFactory value of connectionFactory for this instance of SjmsComponent.
setConnectionResource(ConnectionResource) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
setConsumerCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the number of consumer listeners used for this endpoint.
setConsumers(GenericObjectPool<MessageConsumerResources>) - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
setCorrelationId(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the correlation id on the JMS message.
setCorrelationId(Message, String) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Sets the correlation id on the JMS message.
setDurableSubscriptionId(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the durable subscription Id required for durable topics.
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
setJMSDeliveryMode(Message, Object) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the JMSDeliveryMode on the message.
setJMSDeliveryMode(Exchange, Message, Object) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Sets the JMSDeliveryMode on the message.
setJmsMessageHeaders(Message, Map<String, Object>, KeyFormatStrategy) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Adds or updates the Message headers.
setJmsMessageHeaders(Exchange, Message) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
 
setJmsMessageHeaders(Message, Exchange, boolean) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
 
setJMSReplyTo(Message, Destination) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Sets the JMSReplyTo on the message.
setKeyFormatStrategy(KeyFormatStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
setMessageSelector(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the JMS Message selector syntax.
setMessageType(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the correlation id on the JMS message.
setNamedReplyTo(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the reply to destination name used for InOut producer endpoints.
setPassword(String) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setPersistent(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Flag used to enable/disable message persistence.
setPrefillPool(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
setProcessor(AsyncProcessor) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setProducerCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the number of producers used for this endpoint.
setProducers(GenericObjectPool<MessageProducerResources>) - Method in class org.apache.camel.component.sjms.SjmsProducer
Sets the producer pool for this instance of SjmsProducer.
setProperty(Message, String, Object) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the property on the given JMS message.
setProperty(Message, String, Object) - Static method in class org.apache.camel.component.sjms.SjmsExchangeMessageHelper
Sets the property on the given JMS message.
setResponseTimeOut(long) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the amount of time we should wait before timing out a InOut response.
setSession(Session) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setSessionCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Deprecated.
setSynchronous(boolean) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setSynchronous(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Flag can be set to enable/disable synchronous exchange processing.
setTimedTaskManager(TimedTaskManager) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
setTopic(boolean) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setTransacted(boolean) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setTransacted(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Enable/disable flag for transactions
setTransactionBatchCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
If transacted sets the number of messages to process before committing a transaction.
setTransactionBatchTimeout(long) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets timeout value for batch transactions.
setTransactionCommitStrategy(TransactionCommitStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
Sets the TransactionCommitStrategy value of transactionCommitStrategy for this instance of SjmsComponent.
setTransactionCommitStrategy(TransactionCommitStrategy) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the commit strategy.
setTtl(long) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Flag used to adjust the Time To Live value of produced messages.
setUsername(String) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
size() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
SjmsComponent - Class in org.apache.camel.component.sjms
The Simple JMS component.
SjmsComponent() - Constructor for class org.apache.camel.component.sjms.SjmsComponent
 
SjmsConstants - Class in org.apache.camel.component.sjms
 
SjmsConsumer - Class in org.apache.camel.component.sjms
The SjmsConsumer is the base class for the SJMS MessageListener pool.
SjmsConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.component.sjms.SjmsConsumer
 
SjmsConsumer.MessageConsumerResourcesFactory - Class in org.apache.camel.component.sjms
A pool of MessageConsumerResources created at the initialization of the associated consumer.
SjmsConsumer.MessageConsumerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.SjmsConsumer.MessageConsumerResourcesFactory
 
SjmsEndpoint - Class in org.apache.camel.component.sjms
A JMS Endpoint
SjmsEndpoint() - Constructor for class org.apache.camel.component.sjms.SjmsEndpoint
 
SjmsEndpoint(String, Component) - Constructor for class org.apache.camel.component.sjms.SjmsEndpoint
 
SjmsExchangeMessageHelper - Class in org.apache.camel.component.sjms
 
SjmsHeaderFilterStrategy - Class in org.apache.camel.component.sjms
 
SjmsHeaderFilterStrategy() - Constructor for class org.apache.camel.component.sjms.SjmsHeaderFilterStrategy
 
SjmsProducer - Class in org.apache.camel.component.sjms
Base SjmsProducer class.
SjmsProducer(Endpoint) - Constructor for class org.apache.camel.component.sjms.SjmsProducer
 
SjmsProducer.MessageProducerResourcesFactory - Class in org.apache.camel.component.sjms
The MessageProducerResources pool for all SjmsProducer classes.
SjmsProducer.MessageProducerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.SjmsProducer.MessageProducerResourcesFactory
 

T

TEMP_QUEUE_PREFIX - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 
TEMP_TOPIC_PREFIX - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 
TimedTaskManager - Class in org.apache.camel.component.sjms.taskmanager
A thread safe task manager that allows you to add and cancel TimerTask objects.
TimedTaskManager() - Constructor for class org.apache.camel.component.sjms.taskmanager.TimedTaskManager
 
TOPIC_PREFIX - Static variable in class org.apache.camel.component.sjms.SjmsConstants
 
toString() - Method in class org.apache.camel.component.sjms.BatchMessage
 
TransactionCommitStrategy - Interface in org.apache.camel.component.sjms
Provides a entry point into the transaction Synchronization workflow that will allow a user to control when the Session commit operation is executed.

V

valueOf(String) - Static method in enum org.apache.camel.component.sjms.jms.JmsMessageHeaderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.component.sjms.jms.JmsMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.component.sjms.jms.SessionAcknowledgementType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.component.sjms.jms.JmsMessageHeaderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.component.sjms.jms.JmsMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.component.sjms.jms.SessionAcknowledgementType
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F G H I J K L M N O P Q R S T V 

Apache Camel