Class ActiveMQEndpoint

  • All Implemented Interfaces:
    AutoCloseable, org.apache.camel.AsyncEndpoint, org.apache.camel.CamelContextAware, org.apache.camel.Endpoint, org.apache.camel.IsSingleton, org.apache.camel.MultipleConsumersSupport, org.apache.camel.Service, org.apache.camel.ShutdownableService, org.apache.camel.spi.HasId, org.apache.camel.spi.HeaderFilterStrategyAware, org.apache.camel.StatefulService, org.apache.camel.SuspendableService
    Direct Known Subclasses:
    ActiveMQQueueEndpoint

    @UriEndpoint(firstVersion="1.0.0",
                 extendsScheme="jms",
                 scheme="activemq",
                 title="ActiveMQ",
                 syntax="activemq:destinationType:destinationName",
                 category=MESSAGING)
    public class ActiveMQEndpoint
    extends org.apache.camel.component.jms.JmsEndpoint
    Send messages to (or consume from) Apache ActiveMQ. This component extends the Camel JMS component.
    • Field Summary

      • Fields inherited from class org.apache.camel.support.service.BaseService

        BUILT, FAILED, INITIALIZED, INITIALIZING, lock, NEW, SHUTDOWN, SHUTTING_DOWN, STARTED, STARTING, status, STOPPED, STOPPING, SUSPENDED, SUSPENDING
    • Constructor Summary

      Constructors 
      Constructor Description
      ActiveMQEndpoint()  
      ActiveMQEndpoint​(String endpointUri, String destinationName)  
      ActiveMQEndpoint​(String endpointUri, String destinationName, boolean pubSubDomain)  
      ActiveMQEndpoint​(String endpointUri, org.apache.camel.component.jms.JmsBinding binding, org.apache.camel.component.jms.JmsConfiguration configuration, String destinationName, boolean pubSubDomain)  
      ActiveMQEndpoint​(String uri, org.apache.camel.component.jms.JmsComponent component, String destinationName, boolean pubSubDomain, org.apache.camel.component.jms.JmsConfiguration configuration)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      Map<String,​String> getDestinationOptions()  
      void setDestinationOptions​(Map<String,​String> destinationOptions)
      Destination Options are a way to provide extended configuration options to a JMS consumer without having to extend the JMS API.
      • Methods inherited from class org.apache.camel.component.jms.JmsEndpoint

        configureListenerContainer, createBinding, createConsumer, createConsumer, createEndpointUri, createExchange, createExchange, createInOnlyTemplate, createInOutTemplate, createMessageListenerContainer, createPollingConsumer, createProducer, createReplyToMessageListenerContainer, getAcknowledgementMode, getAcknowledgementModeName, getAllowAdditionalHeaders, getAsyncStartStopExecutorService, getBinding, getCacheLevel, getCacheLevelName, getClientId, getComponent, getConcurrentConsumers, getConfiguration, getConnectionFactory, getDefaultTaskExecutorType, getDeliveryMode, getDestinationName, getDestinationResolver, getDestinationType, getDurableSubscriptionName, getEagerPoisonBody, getEndpointConfiguredDestinationName, getErrorHandler, getErrorHandlerLoggingLevel, getExceptionListener, getHeaderFilterStrategy, getIdleConsumerLimit, getIdleTaskExecutionLimit, getJmsKeyFormatStrategy, getJmsMessageType, getJmsOperations, getListenerConnectionFactory, getMaxConcurrentConsumers, getMaxMessagesPerTask, getMessageConverter, getMessageCreatedStrategy, getMessageListenerContainerFactory, getPriority, getReceiveTimeout, getRecoveryInterval, getReplyTo, getReplyToCacheLevelName, getReplyToConcurrentConsumers, getReplyToDestinationSelectorName, getReplyToMaxConcurrentConsumers, getReplyToOnTimeoutMaxConcurrentConsumers, getReplyToOverride, getReplyToType, getRequestTimeout, getRequestTimeoutCheckerInterval, getRunningMessageListeners, getSelector, getSubscriptionName, getTaskExecutor, getTemplateConnectionFactory, 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, isUseMessageIDAsCorrelationID, 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, setDestinationName, setDestinationResolver, setDestinationType, setDisableReplyTo, setDisableTimeToLive, setDurableSubscriptionName, setEagerLoadingOfProperties, setEagerPoisonBody, setErrorHandler, setErrorHandlerLogStackTrace, setExceptionListener, setExplicitQosEnabled, setExposeListenerSession, setForceSendOriginalMessage, setFormatDateHeadersToIso8601, setHeaderFilterStrategy, setIdleConsumerLimit, setIdleTaskExecutionLimit, setIncludeAllJMSXProperties, setIncludeSentJMSMessageID, setJmsKeyFormatStrategy, setJmsMessageType, setJmsOperations, setLazyCreateTransactionManager, setListenerConnectionFactory, setMaxConcurrentConsumers, setMaxMessagesPerTask, setMessageConverter, setMessageCreatedStrategy, setMessageIdEnabled, setMessageListenerContainerFactory, setMessageTimestampEnabled, setPreserveMessageQos, setPriority, setPubSubNoLocal, setReceiveTimeout, setRecoveryInterval, setReplyTo, setReplyToCacheLevelName, setReplyToConcurrentConsumers, setReplyToDeliveryPersistent, setReplyToDestinationSelectorName, setReplyToMaxConcurrentConsumers, setReplyToOverride, setReplyToSameDestinationAllowed, setReplyToType, setRequestTimeout, setSelector, setSubscriptionDurable, setSubscriptionName, setSubscriptionShared, setTaskExecutor, setTemplateConnectionFactory, setTestConnectionOnStartup, setTimeToLive, setTransacted, setTransactionManager, setTransactionName, setTransactionTimeout, setTransferException, setTransferExchange, setUseMessageIDAsCorrelationID, setWaitForProvisionCorrelationToBeUpdatedCounter, setWaitForProvisionCorrelationToBeUpdatedThreadSleepingTime, shutdown, stop
      • Methods inherited from class org.apache.camel.support.DefaultEndpoint

        configureConsumer, configureExchange, configurePollingConsumer, configureProperties, createAsyncProducer, createExchange, doInit, doStart, doStop, equals, getCamelContext, getEndpointKey, getEndpointUri, getExceptionHandler, getExchangePattern, getId, getPollingConsumerBlockTimeout, getPollingConsumerQueueSize, hashCode, isAutowiredEnabled, isBridgeErrorHandler, isLazyStartProducer, isLenientProperties, isPollingConsumerBlockWhenFull, isPollingConsumerCopy, isSingleton, setAutowiredEnabled, setBridgeErrorHandler, setCamelContext, setComponent, setEndpointUri, setEndpointUriIfNotSpecified, setExceptionHandler, setExchangePattern, setLazyStartProducer, setPollingConsumerBlockTimeout, setPollingConsumerBlockWhenFull, setPollingConsumerCopy, setPollingConsumerQueueSize, setProperties, toString
      • Methods inherited from class org.apache.camel.support.service.BaseService

        build, doBuild, doFail, doLifecycleChange, doResume, doShutdown, doSuspend, fail, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, start, suspend
      • Methods inherited from interface org.apache.camel.Endpoint

        configureExchange, configureProperties, createAsyncProducer, createExchange, getCamelContext, getEndpointBaseUri, getEndpointKey, getEndpointUri, getExchangePattern, isLenientProperties, isSingletonProducer, setCamelContext
      • Methods inherited from interface org.apache.camel.IsSingleton

        isSingleton
      • Methods inherited from interface org.apache.camel.Service

        build, close, init, start
      • Methods inherited from interface org.apache.camel.StatefulService

        getStatus, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isSuspending
      • Methods inherited from interface org.apache.camel.SuspendableService

        isSuspended, resume, suspend
    • Constructor Detail

      • ActiveMQEndpoint

        public ActiveMQEndpoint()
      • ActiveMQEndpoint

        public ActiveMQEndpoint​(String uri,
                                org.apache.camel.component.jms.JmsComponent component,
                                String destinationName,
                                boolean pubSubDomain,
                                org.apache.camel.component.jms.JmsConfiguration configuration)
      • ActiveMQEndpoint

        public ActiveMQEndpoint​(String endpointUri,
                                org.apache.camel.component.jms.JmsBinding binding,
                                org.apache.camel.component.jms.JmsConfiguration configuration,
                                String destinationName,
                                boolean pubSubDomain)
      • ActiveMQEndpoint

        public ActiveMQEndpoint​(String endpointUri,
                                String destinationName,
                                boolean pubSubDomain)
      • ActiveMQEndpoint

        public ActiveMQEndpoint​(String endpointUri,
                                String destinationName)
    • Method Detail

      • getDestinationOptions

        public Map<String,​String> getDestinationOptions()
      • setDestinationOptions

        public void setDestinationOptions​(Map<String,​String> destinationOptions)
        Destination Options are a way to provide extended configuration options to a JMS consumer without having to extend the JMS API. The options are encoded using URL query syntax in the destination name that the consumer is created on. See more details at https://activemq.apache.org/destination-options.