public class JmsTemporaryQueueEndpoint extends JmsQueueEndpoint implements DestinationEndpoint
TemporaryQueue
Important: Need to be really careful to always use the same Connection otherwise the destination goes stalelog
Constructor and Description |
---|
JmsTemporaryQueueEndpoint(String uri,
JmsComponent component,
String destination,
JmsConfiguration configuration) |
JmsTemporaryQueueEndpoint(String uri,
JmsComponent component,
String destination,
JmsConfiguration configuration,
QueueBrowseStrategy queueBrowseStrategy) |
JmsTemporaryQueueEndpoint(String endpointUri,
String destination) |
JmsTemporaryQueueEndpoint(javax.jms.TemporaryQueue jmsDestination) |
Modifier and Type | Method and Description |
---|---|
protected javax.jms.Destination |
createJmsDestination(javax.jms.Session session) |
javax.jms.Destination |
getJmsDestination(javax.jms.Session session) |
boolean |
isSingleton()
This endpoint is a singleton so that the temporary destination instances are shared across all
producers and consumers of the same endpoint URI
|
createQueueBrowseStrategy, getExchanges, getMaximumBrowseSize, setMaximumBrowseSize
configureListenerContainer, createBinding, createConsumer, createConsumer, createEndpointUri, createExchange, createExchange, createInOnlyTemplate, createInOutTemplate, createMessageListenerContainer, createPollingConsumer, createProducer, getAcknowledgementMode, getAcknowledgementModeName, getAllowAdditionalHeaders, getAsyncStartStopExecutorService, getBinding, getCacheLevel, getCacheLevelName, getClientId, getComponent, getConcurrentConsumers, getConfiguration, getConnectionFactory, getDefaultTaskExecutorType, getDeliveryMode, getDestination, getDestinationName, getDestinationResolver, getDestinationType, getDurableSubscriptionName, getEndpointConfiguredDestinationName, getErrorHandler, getErrorHandlerLoggingLevel, getExceptionListener, getHeaderFilterStrategy, getIdleConsumerLimit, getIdleTaskExecutionLimit, getJmsKeyFormatStrategy, getJmsMessageType, getJmsOperations, getListenerConnectionFactory, getMaxConcurrentConsumers, getMaxMessagesPerTask, getMessageConverter, getMessageCreatedStrategy, getMessageListenerContainerFactory, getMetadataJmsOperations, getMetadataJmsOperations, getPriority, getProviderMetadata, getReceiveTimeout, getRecoveryInterval, getReplyTo, getReplyToCacheLevelName, getReplyToConcurrentConsumers, getReplyToDestinationSelectorName, getReplyToMaxConcurrentConsumers, getReplyToOnTimeoutMaxConcurrentConsumers, getReplyToOverride, getReplyToType, getRequestTimeout, getRequestTimeoutCheckerInterval, getRunningMessageListeners, getSelector, getSubscriptionName, getTaskExecutor, getTemplateConnectionFactory, getTemporaryQueueType, getTemporaryTopicType, getThreadName, getTimeToLive, getTransactionManager, getTransactionName, getTransactionTimeout, getWaitForProvisionCorrelationToBeUpdatedCounter, getWaitForProvisionCorrelationToBeUpdatedThreadSleepingTime, isAcceptMessagesWhileStopping, isAllowNullBody, isAllowReplyManagerQuickStop, isAllowSerializedHeaders, isAlwaysCopyMessage, isArtemisStreamingEnabled, isAsyncConsumer, isAsyncStartListener, isAsyncStopListener, isAutoStartup, isDeliveryPersistent, isDisableReplyTo, isDisableTimeToLive, isEagerLoadingOfProperties, isErrorHandlerLogStackTrace, isExplicitQosEnabled, isExposeListenerSession, isForceSendOriginalMessage, isFormatDateHeadersToIso8601, isIncludeAllJMSXProperties, isIncludeSentJMSMessageID, isLazyCreateTransactionManager, isMessageIdEnabled, isMessageTimestampEnabled, isMultipleConsumersSupported, isPreserveMessageQos, isPubSubDomain, isPubSubNoLocal, isReplyToDeliveryPersistent, isReplyToSameDestinationAllowed, isRunning, isSubscriptionDurable, isSubscriptionShared, isTestConnectionOnStartup, isTransacted, isTransactedInOut, isTransferException, isTransferExchange, isTransferFault, isUseMessageIDAsCorrelationID, newInstance, newInstance, onListenerContainerStarting, onListenerContainerStopped, setAcceptMessagesWhileStopping, setAcknowledgementMode, setAcknowledgementModeName, setAllowAdditionalHeaders, setAllowNullBody, setAllowReplyManagerQuickStop, setAllowSerializedHeaders, setAlwaysCopyMessage, setArtemisStreamingEnabled, setAsyncConsumer, setAsyncStartListener, setAsyncStopListener, setAutoStartup, setBinding, setCacheLevel, setCacheLevelName, setClientId, setConcurrentConsumers, setConfiguration, setConnectionFactory, setDefaultTaskExecutorType, setDeliveryMode, setDeliveryPersistent, setDestination, setDestinationName, setDestinationResolver, setDestinationType, setDisableReplyTo, setDisableTimeToLive, setDurableSubscriptionName, setEagerLoadingOfProperties, setErrorHandler, setErrorHandlerLogStackTrace, setExceptionListener, setExplicitQosEnabled, setExposeListenerSession, setForceSendOriginalMessage, setFormatDateHeadersToIso8601, setHeaderFilterStrategy, setIdleConsumerLimit, setIdleTaskExecutionLimit, setIncludeAllJMSXProperties, setIncludeSentJMSMessageID, setJmsKeyFormatStrategy, setJmsMessageType, setJmsOperations, setLazyCreateTransactionManager, setListenerConnectionFactory, setMaxConcurrentConsumers, setMaxMessagesPerTask, setMessageConverter, setMessageCreatedStrategy, setMessageIdEnabled, setMessageListenerContainerFactory, setMessageTimestampEnabled, setMetadataJmsOperations, setPreserveMessageQos, setPriority, setProviderMetadata, setPubSubNoLocal, setReceiveTimeout, setRecoveryInterval, setReplyTo, setReplyToCacheLevelName, setReplyToConcurrentConsumers, setReplyToDeliveryPersistent, setReplyToDestinationSelectorName, setReplyToMaxConcurrentConsumers, setReplyToOverride, setReplyToSameDestinationAllowed, setReplyToType, setRequestTimeout, setSelector, setSubscriptionDurable, setSubscriptionName, setSubscriptionShared, setTaskExecutor, setTemplateConnectionFactory, setTestConnectionOnStartup, setTimeToLive, setTransacted, setTransactedInOut, setTransactionManager, setTransactionName, setTransactionTimeout, setTransferException, setTransferExchange, setTransferFault, setUseMessageIDAsCorrelationID, setWaitForProvisionCorrelationToBeUpdatedCounter, setWaitForProvisionCorrelationToBeUpdatedThreadSleepingTime, shutdown, stop
configureConsumer, configurePollingConsumer, configureProperties, createEndpointConfiguration, createExchange, createExchange, doStart, doStop, equals, getCamelContext, getConsumerProperties, getEndpointConfiguration, getEndpointKey, getEndpointUri, getExceptionHandler, getExchangePattern, getId, getPollingConsumerBlockTimeout, getPollingConsumerQueueSize, hashCode, isBridgeErrorHandler, isLenientProperties, isPollingConsumerBlockWhenFull, isSynchronous, setBridgeErrorHandler, setCamelContext, setConsumerProperties, setEndpointConfiguration, setEndpointUri, setEndpointUriIfNotSpecified, setExceptionHandler, setExchangePattern, setPollingConsumerBlockTimeout, setPollingConsumerBlockWhenFull, setPollingConsumerQueueSize, setProperties, setSynchronous, toString
doResume, doShutdown, doSuspend, getStatus, getVersion, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, start, suspend
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
public JmsTemporaryQueueEndpoint(String uri, JmsComponent component, String destination, JmsConfiguration configuration)
public JmsTemporaryQueueEndpoint(String uri, JmsComponent component, String destination, JmsConfiguration configuration, QueueBrowseStrategy queueBrowseStrategy)
public JmsTemporaryQueueEndpoint(javax.jms.TemporaryQueue jmsDestination) throws javax.jms.JMSException
javax.jms.JMSException
public boolean isSingleton()
isSingleton
in interface org.apache.camel.IsSingleton
isSingleton
in class JmsEndpoint
public javax.jms.Destination getJmsDestination(javax.jms.Session session) throws javax.jms.JMSException
getJmsDestination
in interface DestinationEndpoint
javax.jms.JMSException
protected javax.jms.Destination createJmsDestination(javax.jms.Session session) throws javax.jms.JMSException
javax.jms.JMSException
Apache Camel