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

A

AbstractMessageHandler - Class in org.apache.camel.component.sjms.consumer
Abstract MessageListener
AbstractMessageHandler(SjmsEndpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
AbstractMessageHandler(SjmsEndpoint, 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
 
allowHandover() - Method in class org.apache.camel.component.sjms.tx.SessionTransactionSynchronization
 
appendJmsProperties(Message, Exchange, Map<String, Object>) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Appends the JMS headers from the Camel Message
appendJmsProperty(Message, Exchange, String, Object) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 

B

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
 
CloseProducerCallback() - Constructor for class org.apache.camel.component.sjms.SjmsProducer.CloseProducerCallback
 
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
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponentConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpointConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.sjms.SjmsComponentConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpointConfigurer
 
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
 
ConnectionFactoryResource(int, ConnectionFactory, String, String, String, long, boolean) - 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
 
copyFrom(Message) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
createBinding() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Creates the JmsBinding to use.
createBinding() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Creates the JmsBinding to use.
createBody() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
createByteArrayFromBytesMessage(BytesMessage) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 
createConnectionResource(Object) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createDestination(Session, String, boolean) - Method in class org.apache.camel.component.sjms.jms.DefaultDestinationCreationStrategy
 
createDestination(Session, String, boolean) - Method in interface org.apache.camel.component.sjms.jms.DestinationCreationStrategy
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
createExchange(Message, Session) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
createExchange(Message, Session) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createJmsMessage(Exception, Session) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 
createJmsMessage(Exchange, Object, Map<String, Object>, Session, CamelContext) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 
createJmsMessageForType(Exchange, Object, Map<String, Object>, Session, CamelContext, JmsMessageType) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Create the Message
createMapFromMapMessage(MapMessage) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Extracts a Map from a MapMessage
createMessageConsumer(Session, Endpoint) - Method in class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
createMessageConsumer(Session, Destination, String, boolean, String, boolean, boolean) - Method in class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
createMessageConsumer(Session, Destination, String, boolean, String, boolean, boolean, boolean) - Method in class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
createMessageConsumer(Session, Endpoint) - Method in interface org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageConsumer(Session, Destination, String, boolean, String, boolean, boolean) - Method in interface org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageConsumer(Session, Destination, String, boolean, String, boolean, boolean, boolean) - Method in interface 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
createMessageId() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
createMessageProducer(Session, Endpoint) - Method in class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
createMessageProducer(Session, Destination, boolean, long) - Method in class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
createMessageProducer(Session, Endpoint) - Method in interface org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createMessageProducer(Session, Destination, boolean, long) - Method in interface org.apache.camel.component.sjms.jms.JmsObjectFactory
 
createProducer() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
createProducer() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
createSession() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
createSjmsEndpoint(String, String) - Method in class org.apache.camel.component.sjms.SjmsComponent
 
createTemporaryDestination(Session, boolean) - Method in class org.apache.camel.component.sjms.jms.DefaultDestinationCreationStrategy
 
createTemporaryDestination(Session, boolean) - Method in interface org.apache.camel.component.sjms.jms.DestinationCreationStrategy
 

D

decodeKey(String) - Method in class org.apache.camel.component.sjms.jms.DefaultJmsKeyFormatStrategy
 
decodeKey(String) - Method in interface org.apache.camel.component.sjms.jms.JmsKeyFormatStrategy
Decodes the key after its received from a Message message.
DEFAULT_COMPLETION_SIZE - Static variable in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
DEFAULT_COMPLETION_TIMEOUT - Static variable in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
DefaultDestinationCreationStrategy - Class in org.apache.camel.component.sjms.jms
Default implementation of DestinationCreationStrategy, delegates to Session.createTopic and Session.createQueue.
DefaultDestinationCreationStrategy() - Constructor for class org.apache.camel.component.sjms.jms.DefaultDestinationCreationStrategy
 
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
 
DestinationCreationStrategy - Interface in org.apache.camel.component.sjms.jms
Strategy for creating Destination's
DestinationNameParser - Class in org.apache.camel.component.sjms.jms
 
DestinationNameParser() - Constructor for class org.apache.camel.component.sjms.jms.DestinationNameParser
 
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
 
doCreateProducerModel(Session) - 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.MessageHandlerAsyncCallback
 
doShutdown() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
doShutdown() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
doStart() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
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.batch.SjmsBatchConsumer
 
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.JmsKeyFormatStrategy
Encodes the key before its sent as a Message message.
ensureInitialHeaders() - Method in class org.apache.camel.component.sjms.SjmsMessage
Ensure that the headers have been populated from the underlying JMS message before we start mutating the headers
extractBodyFromJms(Exchange, Message) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Extracts the body from the JMS message
extractHeadersFromJms(Message, Exchange) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 

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
 
getAcknowledgeMode() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the acknowledgment mode for this instance of DestinationProducer.
getAggregationStrategy() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getAsyncStartStopExecutorService() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
getAsyncStartStopExecutorService() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getBinding() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getBinding() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getBinding() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
getClientId() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
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.producer.InOnlyProducer
 
getCommitStrategy() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets commitStrategy for this instance of SjmsProducer.
getCompletionInterval() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getCompletionPredicate() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getCompletionSize() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getCompletionTimeout() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getComponent() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getComponent() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getConnectionClientId() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionCount() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionFactory() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getConnectionMaxWait() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConnectionPassword() - Method in class org.apache.camel.component.sjms.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
getConnectionUsername() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getConsumerCount() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
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
 
getConsumerCount() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets consumerCount for this instance of SjmsProducer.
getDestinationCreationStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getDestinationCreationStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getDestinationName() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The destination name.
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
 
getEndpoint() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
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
 
getErrorHandlerLoggingLevel() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getExceptionListener() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getExceptionListener() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getExecutor() - Method in class org.apache.camel.component.sjms.SjmsProducer
Gets the executor for this instance of SjmsProducer.
getHeader(String) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
getHeaderFilterStrategy() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getHeaderFilterStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getHeaders() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
getJMSCorrelationIDAsBytes(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the JMSCorrelationIDAsBytes from the message.
getJmsKeyFormatStrategy() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getJmsKeyFormatStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getJmsKeyFormatStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getJmsMessage() - Method in class org.apache.camel.component.sjms.SjmsMessage
Returns the underlying JMS message
getJMSMessageID(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the JMSMessageID from the message.
getJMSMessageTypeForBody(Exchange, Object, Map<String, Object>, Session, CamelContext) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Return the JmsMessageType
getJmsObjectFactory() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getJMSRedelivered(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the JMSRedelivered from the message.
getJMSReplyTo(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the JMSReplyTo from the message.
getJmsSession() - Method in class org.apache.camel.component.sjms.SjmsMessage
Returns the underlying JMS session.
getJMSType(Message) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the JMSType from the message.
getKeepAliveDelay() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getMessageConsumer() - Method in class org.apache.camel.component.sjms.MessageConsumerResources
 
getMessageCreatedStrategy() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getMessageCreatedStrategy() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getMessageCreatedStrategy() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
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
 
getNamedReplyTo() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
getNamedReplyTo() - Method in class org.apache.camel.component.sjms.SjmsProducer
Returns the named reply to value for this producer
getObjectProperty(Message, String) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
 
getOrCreateConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsConsumer
 
getOrCreateConnectionResource() - Method in class org.apache.camel.component.sjms.SjmsProducer
 
getPassword() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
getPollDuration() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
getProcessor() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
getProducerCount() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
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.
getProperty(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets a JMS property
getRecoveryInterval() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
getRecoveryInterval() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
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
 
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.
getShortName(String) - Method in class org.apache.camel.component.sjms.jms.DestinationNameParser
 
getStringProperty(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Gets the String Properties from the message.
getTimedTaskManager() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
getTimeoutCheckerExecutorService() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
getTimeoutCheckerExecutorService() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
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
 
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
 
getTransactionCommitStrategy() - Method in class org.apache.camel.component.sjms.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
 
getTtl() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
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
 
getUuidGenerator() - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
getValidJMSHeaderValue(String, Object) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Strategy to test if the given header is valid according to the JMS spec to be set as a property on the JMS message.

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
 
hasProperty(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
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(SjmsEndpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
InOnlyMessageHandler(SjmsEndpoint, ExecutorService, Synchronization) - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler
 
InOnlyMessageHandler.NoOpAsyncCallback - Class in org.apache.camel.component.sjms.consumer
 
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(SjmsEndpoint, ExecutorService) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
InOutMessageHandler(SjmsEndpoint, ExecutorService, Synchronization) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler
 
InOutMessageHandler.MessageHandlerAsyncCallback - Class in org.apache.camel.component.sjms.consumer
 
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.MessageConsumerResourcesFactory - Class in org.apache.camel.component.sjms.producer
A pool of MessageConsumerResources objects that are the reply consumers.
intValue() - Method in enum org.apache.camel.component.sjms.jms.SessionAcknowledgementType
 
isAllowNullBody() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isAllowNullBody() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isAsyncStartListener() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
isAsyncStartListener() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isAsyncStartListener() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isAsyncStopListener() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isConnectionTestOnBorrow() - Method in class org.apache.camel.component.sjms.SjmsComponent
 
isEagerCheckCompletion() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isEndpointTransacted() - Method in class org.apache.camel.component.sjms.SjmsProducer
Test to determine if this endpoint should use a JMS Transaction.
isErrorHandlerLogStackTrace() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isIncludeAllJMSXProperties() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isIncludeAllJMSXProperties() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isMapJmsMessage() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isMapJmsMessage() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isMultipleConsumersSupported() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isNamedReplyToTopic(String, boolean) - Method in class org.apache.camel.component.sjms.jms.DestinationNameParser
 
isPersistent() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
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
 
isQueuePrefix(String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Whether the destination name has either queue or temp queue prefix.
isSendEmptyMessageWhenIdle() - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
isSharedJMSSession() - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
isSharedJMSSession() - Method in class org.apache.camel.component.sjms.SjmsConsumer
Use to determine if JMS session should be propagated to share with other SJMS endpoints.
isSharedJMSSession() - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
isSharedJMSSession() - Method in class org.apache.camel.component.sjms.SjmsProducer
Test to determine if this endpoint should share a JMS Session with other SJMS endpoints.
isStandardJMSHeader(String) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Is the given header a standard JMS header
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
 
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(String) - Method in class org.apache.camel.component.sjms.jms.DestinationNameParser
 
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.
isTopicPrefix(String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Whether the destination name has either topic or temp topic prefix.
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
 
isTransactedRedelivered() - Method in class org.apache.camel.component.sjms.SjmsMessage
 

J

Jms11ObjectFactory - Class in org.apache.camel.component.sjms.jms
JMS 1.1 object factory
Jms11ObjectFactory() - Constructor for class org.apache.camel.component.sjms.jms.Jms11ObjectFactory
 
JMS_CORRELATION_ID - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set by the publishing Client
JMS_DELIVERY_MODE - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_DELIVERY_MODE_NON_PERSISTENT - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
 
JMS_DELIVERY_MODE_PERSISTENT - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
String representation of JMS delivery modes.
JMS_DESTINATION - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_EXPIRATION - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_MESSAGE_ID - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_MESSAGE_TYPE - Static variable in interface org.apache.camel.component.sjms.SjmsConstants
 
JMS_PRIORITY - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_REDELIVERED - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
A redelivery flag set by the JMS provider
JMS_REPLY_TO - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
The JMS Reply To Destination set by the publishing Client
JMS_SESSION - Static variable in interface org.apache.camel.component.sjms.SjmsConstants
 
JMS_TIMESTAMP - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set on the send or publish event
JMS_TYPE - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Set by the publishing Client
JmsBinding - Class in org.apache.camel.component.sjms.jms
A Strategy used to convert between a Camel Exchange and Message to and from a JMS Message
JmsBinding(boolean, boolean, HeaderFilterStrategy, JmsKeyFormatStrategy, MessageCreatedStrategy) - Constructor for class org.apache.camel.component.sjms.jms.JmsBinding
 
JmsConstants - Interface in org.apache.camel.component.sjms.jms
JMS constants
JmsKeyFormatStrategy - Interface in org.apache.camel.component.sjms.jms
Strategy for applying encoding and decoding of JMS headers so they apply to the JMS spec.
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 - Interface in org.apache.camel.component.sjms.jms
 
JMSX_GROUP_ID - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
Custom headers

L

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

M

makeJmsMessage(Exchange, Session) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Creates a JMS message from the Camel exchange and message
makeJmsMessage(Exchange, Object, Map, Session, Exception) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Creates a JMS message from the Camel exchange and message
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
 
MessageConsumerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.producer.InOutProducer.MessageConsumerResourcesFactory
 
MessageConsumerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.SjmsConsumer.MessageConsumerResourcesFactory
 
MessageCreatedStrategy - Interface in org.apache.camel.component.sjms.jms
A strategy that allows custom components to plugin and perform custom logic when Camel creates Message instance.
MessageHandlerAsyncCallback(Exchange, MessageProducer) - Constructor for class org.apache.camel.component.sjms.consumer.InOutMessageHandler.MessageHandlerAsyncCallback
 
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
 
MessageProducerResourcesFactory() - Constructor for class org.apache.camel.component.sjms.SjmsProducer.MessageProducerResourcesFactory
 

N

newInstance() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
NoOpAsyncCallback() - Constructor for class org.apache.camel.component.sjms.consumer.InOnlyMessageHandler.NoOpAsyncCallback
 
normalizeDestinationName(String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Normalizes the destination name.
normalizeDestinationName(String, boolean) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Normalizes the destination name.

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
 
onException(JMSException) - Method in class org.apache.camel.component.sjms.SjmsLoggingExceptionListener
 
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
 
onMessageCreated(Message, Session, Exchange, Throwable) - Method in interface org.apache.camel.component.sjms.jms.MessageCreatedStrategy
Callback when the JMS message has just been created, which allows custom modifications afterwards.
org.apache.camel.component.sjms - package org.apache.camel.component.sjms
 
org.apache.camel.component.sjms.batch - package org.apache.camel.component.sjms.batch
 
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
 

P

populateInitialHeaders(Map<String, Object>) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
populateMapMessage(MapMessage, Map<?, ?>, CamelContext) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Populates a MapMessage from a Map instance.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.sjms.SjmsProducer
 

Q

QUEUE_PREFIX - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
 

R

release(MessageProducerResources) - Method in class org.apache.camel.component.sjms.SjmsProducer.CloseProducerCallback
 
release(MessageProducerResources) - Method in interface org.apache.camel.component.sjms.SjmsProducer.ReleaseProducerCallback
 
release(MessageProducerResources) - Method in class org.apache.camel.component.sjms.SjmsProducer.ReturnProducerCallback
 
removeHeader(String) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
removeJmsProperty(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
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.
ReturnProducerCallback() - Constructor for class org.apache.camel.component.sjms.SjmsProducer.ReturnProducerCallback
 
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.batch.SjmsBatchConsumer.StartConsumerTask
 
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, SjmsProducer.ReleaseProducerCallback) - Method in class org.apache.camel.component.sjms.producer.InOnlyProducer
 
sendMessage(Exchange, AsyncCallback, MessageProducerResources, SjmsProducer.ReleaseProducerCallback) - 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, SjmsProducer.ReleaseProducerCallback) - 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 Exchange.
SessionTransactionSynchronization(Session, TransactionCommitStrategy) - Constructor for class org.apache.camel.component.sjms.tx.SessionTransactionSynchronization
 
setAcknowledgementMode(SessionAcknowledgementType) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
The JMS acknowledgement name, which is one of: SESSION_TRANSACTED, CLIENT_ACKNOWLEDGE, AUTO_ACKNOWLEDGE, DUPS_OK_ACKNOWLEDGE
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The aggregation strategy to use, which merges all the batched messages into a single message
setAllowNullBody(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Whether to allow sending messages with no body.
setAllowNullBody(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Whether to allow sending messages with no body.
setAsyncStartListener(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
Whether to startup the consumer message listener asynchronously, when starting a route.
setAsyncStartListener(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Whether to startup the consumer message listener asynchronously, when starting a route.
setAsyncStartListener(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Whether to startup the consumer message listener asynchronously, when starting a route.
setAsyncStopListener(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Whether to stop the consumer message listener asynchronously, when stopping a route.
setBinding(JmsBinding) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Sets the binding used to convert from a Camel message to and from a JMS message
setBinding(JmsBinding) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the binding used to convert from a Camel message to and from a JMS message
setBinding(JmsBinding) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setBody(Object) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setClientId(String) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setCompletionInterval(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The completion interval in millis, which causes batches to be completed in a scheduled fixed rate every interval.
setCompletionPredicate(Predicate) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The completion predicate, which causes batches to be completed when the predicate evaluates as true.
setCompletionPredicate(String) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
setCompletionSize(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The number of messages consumed at which the batch will be completed
setCompletionTimeout(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The timeout in millis from receipt of the first first message when the batch will be completed.
setConnectionClientId(String) - Method in class org.apache.camel.component.sjms.SjmsComponent
The client ID to use when creating Connection when using the default ConnectionFactoryResource.
setConnectionCount(Integer) - Method in class org.apache.camel.component.sjms.SjmsComponent
The maximum number of connections available to endpoints started under this component
setConnectionCount(Integer) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
The maximum number of connections available to this endpoint
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
A ConnectionFactory is required to enable the SjmsBatchComponent.
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.SjmsComponent
A ConnectionFactory is required to enable the SjmsComponent.
setConnectionFactory(ConnectionFactory) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Initializes the connectionFactory for the endpoint, which takes precedence over the component's connectionFactory, if any
setConnectionFactory(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
setConnectionMaxWait(long) - Method in class org.apache.camel.component.sjms.SjmsComponent
The max wait time in millis to block and wait on free connection when the pool is exhausted when using the default ConnectionFactoryResource.
setConnectionPassword(String) - Method in class org.apache.camel.component.sjms.SjmsComponent
The password to use when creating Connection when using the default ConnectionFactoryResource.
setConnectionResource(ConnectionResource) - Method in class org.apache.camel.component.sjms.SjmsComponent
A ConnectionResource is an interface that allows for customization and container control of the ConnectionFactory.
setConnectionResource(ConnectionResource) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Initializes the connectionResource for the endpoint, which takes precedence over the component's connectionResource, if any
setConnectionResource(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
 
setConnectionTestOnBorrow(boolean) - Method in class org.apache.camel.component.sjms.SjmsComponent
When using the default ConnectionFactoryResource then should each Connection be tested (calling start) before returned from the pool.
setConnectionUsername(String) - Method in class org.apache.camel.component.sjms.SjmsComponent
The username to use when creating Connection when using the default ConnectionFactoryResource.
setConsumerCount(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The number of JMS sessions to consume from
setConsumerCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the number of consumer listeners used for this endpoint.
setCorrelationId(Message, String) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the correlation id on the JMS message.
setDestinationCreationStrategy(DestinationCreationStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
To use a custom DestinationCreationStrategy.
setDestinationCreationStrategy(DestinationCreationStrategy) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
To use a custom DestinationCreationStrategy.
setDestinationName(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
DestinationName is a JMS queue or topic name.
setDurableSubscriptionId(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the durable subscription Id required for durable topics.
setEagerCheckCompletion(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Use eager completion checking which means that the completionPredicate will use the incoming Exchange.
setErrorHandlerLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Allows to configure the default errorHandler logging level for logging uncaught exceptions.
setErrorHandlerLogStackTrace(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Allows to control whether stacktraces should be logged or not, by the default errorHandler.
setExceptionListener(ExceptionListener) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
setExceptionListener(ExceptionListener) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Specifies the JMS Exception Listener that is to be notified of any underlying JMS exceptions.
setHeader(String, Object) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
To use a custom HeaderFilterStrategy to filter header to and from Camel message.
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
To use a custom HeaderFilterStrategy to filter header to and from Camel message.
setHeaders(Map<String, Object>) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setIncludeAllJMSXProperties(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Whether to include all JMSXxxx properties when mapping from JMS to Camel Message.
setIncludeAllJMSXProperties(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Whether to include all JMSXxxx properties when mapping from JMS to Camel Message.
setJMSDeliveryMode(Exchange, Message, Object) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the JMSDeliveryMode on the message.
setJmsKeyFormatStrategy(JmsKeyFormatStrategy) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Pluggable strategy for encoding and decoding JMS keys so they can be compliant with the JMS specification.
setJmsKeyFormatStrategy(JmsKeyFormatStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
Pluggable strategy for encoding and decoding JMS keys so they can be compliant with the JMS specification.
setJmsKeyFormatStrategy(JmsKeyFormatStrategy) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Pluggable strategy for encoding and decoding JMS keys so they can be compliant with the JMS specification.
setJmsMessage(Message) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setJmsObjectFactory(JmsObjectFactory) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
To use a custom Jms Object factory
setJMSReplyTo(Message, Destination) - Static method in class org.apache.camel.component.sjms.jms.JmsMessageHelper
Sets the JMSReplyTo on the message.
setJmsSession(Session) - Method in class org.apache.camel.component.sjms.SjmsMessage
 
setKeepAliveDelay(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The delay in millis between attempts to re-establish a valid session.
setMapJmsMessage(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Specifies whether Camel should auto map the received JMS message to a suited payload type, such as javax.jms.TextMessage to a String etc.
setMapJmsMessage(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Specifies whether Camel should auto map the received JMS message to a suited payload type, such as javax.jms.TextMessage to a String etc.
setMessageCreatedStrategy(MessageCreatedStrategy) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
To use the given MessageCreatedStrategy which are invoked when Camel creates new instances of javax.jms.Message objects when Camel is sending a JMS message.
setMessageCreatedStrategy(MessageCreatedStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
To use the given MessageCreatedStrategy which are invoked when Camel creates new instances of javax.jms.Message objects when Camel is sending a JMS message.
setMessageCreatedStrategy(MessageCreatedStrategy) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
To use the given MessageCreatedStrategy which are invoked when Camel creates new instances of javax.jms.Message objects when Camel is sending a JMS message.
setMessageSelector(String) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets the JMS Message selector syntax.
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.
setPollDuration(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
The duration in milliseconds of each poll for messages.
setPrefillPool(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Whether to prefill the producer connection pool on startup, or create connections lazy when needed.
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.
setRecoveryInterval(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchComponent
Specifies the interval between recovery attempts, i.e.
setRecoveryInterval(int) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
Specifies the interval between recovery attempts, i.e.
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.
setSendEmptyMessageWhenIdle(boolean) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
If using completion timeout or interval, then the batch may be empty if the timeout triggered and there was no messages in the batch.
setSession(Session) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setSessionCount(int) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Deprecated.
setSharedJMSSession(boolean) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setSharedJMSSession(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Specifies whether to share JMS session with other SJMS endpoints.
setSynchronous(boolean) - Method in class org.apache.camel.component.sjms.consumer.AbstractMessageHandler
 
setSynchronous(boolean) - Method in class org.apache.camel.component.sjms.SjmsEndpoint
Sets whether synchronous processing should be strictly used or Camel is allowed to use asynchronous processing (if supported).
setTimedTaskManager(TimedTaskManager) - Method in class org.apache.camel.component.sjms.SjmsComponent
To use a custom TimedTaskManager
setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
If using the completionInterval option a background thread is created to trigger the completion interval.
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
Specifies whether to use transacted mode
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 (in millis) for batch transactions, the value should be 1000 or higher.
setTransactionCommitStrategy(TransactionCommitStrategy) - Method in class org.apache.camel.component.sjms.SjmsComponent
To configure which kind of commit strategy to use.
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
 
setUuidGenerator(UuidGenerator) - Method in class org.apache.camel.component.sjms.producer.InOutProducer
 
shouldCreateNewMessage() - Method in class org.apache.camel.component.sjms.SjmsMessage
Returns true if a new JMS message instance should be created to send to the next component
shouldOutputHeader(String, Object, Exchange) - Method in class org.apache.camel.component.sjms.jms.JmsBinding
Strategy to allow filtering of headers which are put on the JMS message

Note: Currently only supports sending java identifiers as keys

size() - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
SJMS_BATCH_TIMEOUT_CHECKER - Static variable in class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
SjmsBatchComponent - Class in org.apache.camel.component.sjms.batch
 
SjmsBatchComponent() - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchComponent
 
SjmsBatchComponentConfigurer - Class in org.apache.camel.component.sjms.batch
Source code generated by org.apache.camel:apt
SjmsBatchComponentConfigurer() - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchComponentConfigurer
 
SjmsBatchConsumer - Class in org.apache.camel.component.sjms.batch
 
SjmsBatchConsumer(SjmsBatchEndpoint, Processor) - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchConsumer
 
SjmsBatchConsumer.StartConsumerTask - Class in org.apache.camel.component.sjms.batch
Task to startup the consumer either synchronously or using asynchronous with recovery
SjmsBatchEndpoint - Class in org.apache.camel.component.sjms.batch
The sjms-batch component is a specialized for highly performant, transactional batch consumption from a JMS queue.
SjmsBatchEndpoint() - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
SjmsBatchEndpoint(String, Component, String) - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchEndpoint
 
SjmsBatchEndpointConfigurer - Class in org.apache.camel.component.sjms.batch
Source code generated by org.apache.camel:apt
SjmsBatchEndpointConfigurer() - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchEndpointConfigurer
 
SjmsComponent - Class in org.apache.camel.component.sjms
The Simple JMS component.
SjmsComponent() - Constructor for class org.apache.camel.component.sjms.SjmsComponent
 
SjmsComponent(Class<? extends Endpoint>) - Constructor for class org.apache.camel.component.sjms.SjmsComponent
 
SjmsComponentConfigurer - Class in org.apache.camel.component.sjms
Source code generated by org.apache.camel:apt
SjmsComponentConfigurer() - Constructor for class org.apache.camel.component.sjms.SjmsComponentConfigurer
 
SjmsConstants - Interface 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.
SjmsEndpoint - Class in org.apache.camel.component.sjms
The sjms component (simple jms) allows messages to be sent to (or consumed from) a JMS Queue or Topic (uses JMS 1.x API).
SjmsEndpoint() - Constructor for class org.apache.camel.component.sjms.SjmsEndpoint
 
SjmsEndpoint(String, Component, String) - Constructor for class org.apache.camel.component.sjms.SjmsEndpoint
 
SjmsEndpointConfigurer - Class in org.apache.camel.component.sjms
Source code generated by org.apache.camel:apt
SjmsEndpointConfigurer() - Constructor for class org.apache.camel.component.sjms.SjmsEndpointConfigurer
 
SjmsHeaderFilterStrategy - Class in org.apache.camel.component.sjms
 
SjmsHeaderFilterStrategy() - Constructor for class org.apache.camel.component.sjms.SjmsHeaderFilterStrategy
 
SjmsHeaderFilterStrategy(boolean) - Constructor for class org.apache.camel.component.sjms.SjmsHeaderFilterStrategy
 
SjmsLoggingExceptionListener - Class in org.apache.camel.component.sjms
A JMS ExceptionListener which logs all caught exceptions.
SjmsLoggingExceptionListener(ExceptionHandler, boolean) - Constructor for class org.apache.camel.component.sjms.SjmsLoggingExceptionListener
 
SjmsMessage - Class in org.apache.camel.component.sjms
Represents a Message for working with JMS
SjmsMessage(Exchange, Message, Session, JmsBinding) - Constructor for class org.apache.camel.component.sjms.SjmsMessage
 
SjmsProducer - Class in org.apache.camel.component.sjms
Base SjmsProducer class.
SjmsProducer(Endpoint) - Constructor for class org.apache.camel.component.sjms.SjmsProducer
 
SjmsProducer.CloseProducerCallback - Class in org.apache.camel.component.sjms
 
SjmsProducer.MessageProducerResourcesFactory - Class in org.apache.camel.component.sjms
The MessageProducerResources pool for all SjmsProducer classes.
SjmsProducer.ReleaseProducerCallback - Interface in org.apache.camel.component.sjms
 
SjmsProducer.ReturnProducerCallback - Class in org.apache.camel.component.sjms
 
StartConsumerTask(boolean, int, int) - Constructor for class org.apache.camel.component.sjms.batch.SjmsBatchConsumer.StartConsumerTask
 

T

TEMP_QUEUE_PREFIX - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
 
TEMP_TOPIC_PREFIX - Static variable in interface org.apache.camel.component.sjms.jms.JmsConstants
 
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 interface org.apache.camel.component.sjms.jms.JmsConstants
 
toString() - Method in class org.apache.camel.component.sjms.SjmsMessage
 
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

validateObject(Connection) - Method in class org.apache.camel.component.sjms.jms.ConnectionFactoryResource
 
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.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 L M N O P Q R S T V 
Skip navigation links

Apache Camel