Uses of Interface
org.apache.activemq.Service
-
Packages that use Service Package Description org.apache.activemq.advisory Support for JMS Advisory messages as well as some helper listeners to listen to the clients, producers and consumers available.org.apache.activemq.broker The core classes for the ActiveMQ Message Broker and its connectors.org.apache.activemq.broker.cluster org.apache.activemq.broker.jmx JMX MBeans for the broker and its core connectors.org.apache.activemq.broker.region Region abstraction and implementations in the Broker.org.apache.activemq.broker.region.cursors Cursors used to page persistent messages into the broker from the storeorg.apache.activemq.broker.region.policy The policies which can be associated with a particular destination or wildcard.org.apache.activemq.broker.region.virtual Implementation classes for Virtual Destinationsorg.apache.activemq.broker.scheduler The Message Scheduler for delayed (or scheduled) message deliveryorg.apache.activemq.broker.scheduler.memory org.apache.activemq.broker.util Some utility Broker Pluginsorg.apache.activemq.broker.view Broker Plugins for visualising the current systemorg.apache.activemq.network Support for federated networks of brokers.org.apache.activemq.network.jms Support for a federated network using a foreign JMS provider.org.apache.activemq.partition org.apache.activemq.plugin org.apache.activemq.plugin.java org.apache.activemq.pool org.apache.activemq.proxy org.apache.activemq.security Plugable Security Adapter framework along with default implementations such as the JAAS implementation.org.apache.activemq.shiro org.apache.activemq.shiro.authc org.apache.activemq.shiro.authz org.apache.activemq.shiro.env org.apache.activemq.shiro.subject org.apache.activemq.store The APIs which need to be implemented for persistent message stores for durable messagingorg.apache.activemq.store.jdbc Message persistence implemented using JDBCorg.apache.activemq.store.jdbc.adapter Implements database/driver apapters to compensate for the wide differences in the BLOB handing of JDBC drivers.org.apache.activemq.store.journal Message persistence using a high performance transaction log via the Journal interface.org.apache.activemq.store.kahadb org.apache.activemq.store.kahadb.plist org.apache.activemq.store.kahadb.scheduler org.apache.activemq.store.memory VM based implementation of message persistenceorg.apache.activemq.thread org.apache.activemq.transport The core Transport abstraction and support classesorg.apache.activemq.transport.amqp A Broker side implementation of the AMQP 3.1 protocol - see http://amqp.org/org.apache.activemq.transport.auto org.apache.activemq.transport.auto.nio org.apache.activemq.transport.discovery Discovery mechanism to discover brokers and clients.org.apache.activemq.transport.discovery.http org.apache.activemq.transport.discovery.masterslave Static discovery implementation for a Master / Slave tupleorg.apache.activemq.transport.discovery.multicast Discovery implementation using multicastorg.apache.activemq.transport.discovery.simple Simple discovery implementation using a static listorg.apache.activemq.transport.discovery.zeroconf org.apache.activemq.transport.failover Fail-Over Transport which will automatically reconnect to a failed transport and choose one of a list of possible transport implementations to use.org.apache.activemq.transport.fanout Fan-out Transport implementation which ensures that a message is sent to multiple destinations such as to ensure multiple brokers received a message for non-durable topic delivery to improve redundancyorg.apache.activemq.transport.http A transport using the HTTP protocol to allow ActiveMQ to tunnel through firewalls.org.apache.activemq.transport.https A transport using the HTTPS protocol (built on top of the HTTP transport) to allow ActiveMQ to tunnel through firewalls using SSL.org.apache.activemq.transport.mock A mock implementation of the Transport layer useful for testingorg.apache.activemq.transport.mqtt A Broker side implementation of the MQTT 3.1 protocol - see http://mqtt.org/org.apache.activemq.transport.multicast A Multicast based Transport implementation.org.apache.activemq.transport.nio org.apache.activemq.transport.reliable The Reliable transport deals with out of order commands as well as dealing with checking for missed commands and possibly re-requesting the replay of dropped commands.org.apache.activemq.transport.stomp An implementation of the Stomp protocol which is a simple wire protocol for writing clients for ActiveMQ in different languages like Ruby, Python, PHP, C etc.org.apache.activemq.transport.tcp TCP/IP based Transport implementation.org.apache.activemq.transport.udp UDP based Transport implementation.org.apache.activemq.transport.vm In-JVM based Transport implementation.org.apache.activemq.transport.ws org.apache.activemq.transport.ws.jetty9 org.apache.activemq.transport.wss org.apache.activemq.usage org.apache.activemq.util org.apache.activemq.xbean -
-
Uses of Service in org.apache.activemq.advisory
Classes in org.apache.activemq.advisory that implement Service Modifier and Type Class Description class
AdvisoryBroker
This broker filter handles tracking the state of the broker for purposes of publishing advisory messages to advisory consumers.class
ConsumerEventSource
An object which can be used to listen to the number of active consumers available on a given destination.class
ProducerEventSource
An object which can be used to listen to the number of active consumers available on a given destination. -
Uses of Service in org.apache.activemq.broker
Subinterfaces of Service in org.apache.activemq.broker Modifier and Type Interface Description interface
Broker
The Message Broker which routes messages, maintains subscriptions and connections, acknowledges messages and handles transactions.interface
Connection
interface
Connector
A connector creates and manages client connections that talk to the Broker.interface
Locker
Represents a lock service to ensure that a broker is the only masterClasses in org.apache.activemq.broker that implement Service Modifier and Type Class Description class
AbstractLocker
class
BrokerBroadcaster
Used to add listeners for Broker actionsclass
BrokerFilter
Allows you to intercept broker operation so that features such as security can be implemented as a pluggable filter.class
BrokerPluginSupport
A useful base class for implementing broker plugins.class
BrokerService
Manages the life-cycle of an ActiveMQ Broker.class
CompositeDestinationBroker
This broker filter handles composite destinations.class
EmptyBroker
Dumb implementation - used to be overriden by listenersclass
ErrorBroker
Implementation of the broker where all it's methods throw an BrokerStoppedException.class
InsertableMutableBrokerFilter
Inserts itself into the BrokerStackclass
LockableServiceSupport
Helper class for working with services that requires lockingclass
MutableBrokerFilter
Like a BrokerFilter but it allows you to switch the getNext().broker.class
SslBrokerService
A BrokerService that allows access to the key and trust managers used by SSL connections.class
TransactionBroker
This broker filter handles the transaction related operations in the Broker interface.class
TransportConnection
class
TransportConnector
class
TransportStatusDetector
Used to provide information on the status of the Connectionclass
UserIDBroker
This broker filter will append the producer's user ID into the JMSXUserID header to allow folks to know reliably who the user was who produced a message.Methods in org.apache.activemq.broker that return Service Modifier and Type Method Description Service[]
BrokerService. getServices()
Methods in org.apache.activemq.broker with parameters of type Service Modifier and Type Method Description void
BrokerService. addService(Service service)
Adds a new service so that it will be started as part of the broker lifecyclevoid
BrokerService. removeService(Service service)
void
BrokerService. setServices(Service[] services)
Sets the services associated with this broker. -
Uses of Service in org.apache.activemq.broker.cluster
Classes in org.apache.activemq.broker.cluster that implement Service Modifier and Type Class Description class
ConnectionSplitBroker
Monitors for client connections that may fail to another broker - but this broker isn't aware they've gone. -
Uses of Service in org.apache.activemq.broker.jmx
Subinterfaces of Service in org.apache.activemq.broker.jmx Modifier and Type Interface Description interface
BrokerViewMBean
interface
ConnectionViewMBean
interface
ConnectorViewMBean
interface
JmsConnectorViewMBean
interface
NetworkBridgeViewMBean
interface
NetworkConnectorViewMBean
interface
ProxyConnectorViewMBean
Classes in org.apache.activemq.broker.jmx that implement Service Modifier and Type Class Description class
BrokerView
class
ConnectionView
class
ConnectorView
class
JmsConnectorView
class
ManagedQueueRegion
class
ManagedRegionBroker
class
ManagedTempQueueRegion
class
ManagedTempTopicRegion
class
ManagedTopicRegion
class
ManagedTransportConnection
A managed transport connectionclass
ManagedTransportConnector
A managed transport connector which can create multiple managed connections as clients connect.class
ManagementContext
An abstraction over JMX MBean registrationclass
NetworkBridgeView
class
NetworkConnectorView
class
ProxyConnectorView
-
Uses of Service in org.apache.activemq.broker.region
Subinterfaces of Service in org.apache.activemq.broker.region Modifier and Type Interface Description interface
Destination
interface
Region
A Region is used to implement the different QOS options available to a broker.Classes in org.apache.activemq.broker.region that implement Service Modifier and Type Class Description class
AbstractRegion
class
AbstractTempRegion
class
BaseDestination
class
DestinationFilter
class
Queue
The Queue is a List of MessageEntry objects that are dispatched to matching subscriptions.class
QueueRegion
class
RegionBroker
Routes Broker operations to the correct messaging regions for processing.class
TempQueue
The Queue is a List of MessageEntry objects that are dispatched to matching subscriptions.class
TempQueueRegion
class
TempTopic
The Topic is a destination that sends a copy of a message to every active Subscription registered.class
TempTopicRegion
class
Topic
The Topic is a destination that sends a copy of a message to every active Subscription registered.class
TopicRegion
-
Uses of Service in org.apache.activemq.broker.region.cursors
Subinterfaces of Service in org.apache.activemq.broker.region.cursors Modifier and Type Interface Description interface
PendingMessageCursor
Interface to pending message (messages awaiting disptach to a consumer) cursorClasses in org.apache.activemq.broker.region.cursors that implement Service Modifier and Type Class Description class
AbstractPendingMessageCursor
Abstract method holder for pending message (messages awaiting disptach to a consumer) cursorclass
AbstractStoreCursor
Store based cursorclass
FilePendingMessageCursor
persist pending messages pending message (messages awaiting dispatch to a consumer) cursorclass
StoreDurableSubscriberCursor
persist pending messages pending message (messages awaiting dispatch to a consumer) cursorclass
StoreQueueCursor
Store based Cursor for Queuesclass
VMPendingMessageCursor
hold pending messages in a linked list (messages awaiting disptach to a consumer) cursor -
Uses of Service in org.apache.activemq.broker.region.policy
Subinterfaces of Service in org.apache.activemq.broker.region.policy Modifier and Type Interface Description interface
SubscriptionRecoveryPolicy
Abstraction to allow different recovery policies to be plugged into the region implementations.Classes in org.apache.activemq.broker.region.policy that implement Service Modifier and Type Class Description class
FixedCountSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will keep a fixed count of last messages.class
FixedSizedSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will keep a fixed amount of memory available in RAM for message history which is evicted in time order.class
LastImageSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will only keep the last message.class
NoSubscriptionRecoveryPolicy
This SubscriptionRecoveryPolicy disable recovery of messages.class
QueryBasedSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will perform a user specific query mechanism to load any messages they may have missed.class
RetainedMessageSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will only keep the last non-zero length message with theActiveMQMessage
.RETAIN_PROPERTY.class
TimedSubscriptionRecoveryPolicy
This implementation ofSubscriptionRecoveryPolicy
will keep a timed buffer of messages around in memory and use that to recover new subscriptions. -
Uses of Service in org.apache.activemq.broker.region.virtual
Classes in org.apache.activemq.broker.region.virtual that implement Service Modifier and Type Class Description class
CompositeDestinationFilter
Represents a compositeDestination
where send()s are replicated to each Destination instance.class
MappedQueueFilter
Creates a mapped Queue that can recover messages from subscription recovery policy of its Virtual Topic.class
SelectorAwareVirtualTopicInterceptor
class
VirtualTopicInterceptor
A Destination which implements Virtual Topic -
Uses of Service in org.apache.activemq.broker.scheduler
Subinterfaces of Service in org.apache.activemq.broker.scheduler Modifier and Type Interface Description interface
JobSchedulerStore
A Job Scheduler Store interface use to manage delay processing of Messaging related jobs.Classes in org.apache.activemq.broker.scheduler that implement Service Modifier and Type Class Description class
SchedulerBroker
-
Uses of Service in org.apache.activemq.broker.scheduler.memory
Classes in org.apache.activemq.broker.scheduler.memory that implement Service Modifier and Type Class Description class
InMemoryJobSchedulerStore
An in-memory JobSchedulerStore implementation used for Brokers that have persistence disabled or when the JobSchedulerStore usage doesn't require a file or DB based store implementation allowing for better performance. -
Uses of Service in org.apache.activemq.broker.util
Classes in org.apache.activemq.broker.util that implement Service Modifier and Type Class Description class
DestinationPathSeparatorBroker
class
DestinationsPlugin
A simple plugin that can be used to export/import runtime destinations.class
LoggingBrokerPlugin
A simple Broker intercepter which allows you to enable/disable logging.class
MulticastTraceBrokerPlugin
A Broker interceptor which allows you to trace all operations to a Multicast socket.class
RedeliveryPlugin
Replace regular DLQ handling with redelivery via a resend to the original destination after a delay A destination matching RedeliveryPolicy controls the quantity and delay for re-sends If there is no matching policy or an existing policy limit is exceeded by default regular DLQ processing resumes.class
TimeStampingBrokerPlugin
A Broker interceptor which updates a JMS Client's timestamp on the message with a broker timestamp.class
TraceBrokerPathPlugin
The TraceBrokerPathPlugin can be used in a network of Brokers.class
UDPTraceBrokerPlugin
A Broker interceptor which allows you to trace all operations to a UDP socket. -
Uses of Service in org.apache.activemq.broker.view
Classes in org.apache.activemq.broker.view that implement Service Modifier and Type Class Description class
ConnectionDotFileInterceptor
class
DestinationDotFileInterceptor
class
DotFileInterceptorSupport
Useful base class -
Uses of Service in org.apache.activemq.network
Subinterfaces of Service in org.apache.activemq.network Modifier and Type Interface Description interface
NetworkBridge
Represents a network bridge interfaceClasses in org.apache.activemq.network that implement Service Modifier and Type Class Description class
CompositeDemandForwardingBridge
A demand forwarding bridge which works with multicast style transports where a single Transport could be communicating with multiple remote brokersclass
ConduitBridge
Consolidates subscriptionsclass
DemandForwardingBridge
Forwards messages from the local broker to the remote broker based on demand.class
DemandForwardingBridgeSupport
A useful base class for implementing demand forwarding bridges.class
DiscoveryNetworkConnector
A network connector which uses a discovery agent to detect the remote brokers available and setup a connection to each available remote brokerclass
DurableConduitBridge
Consolidates subscriptionsclass
ForwardingBridge
Forwards all messages from the local broker to the remote broker.class
LdapNetworkConnector
class to create dynamic network connectors listed in an directory server using the LDAP v3 protocol as defined in RFC 2251, the entries listed in the directory server must implement the ipHost and ipService objectClasses as defined in RFC 2307.class
MulticastNetworkConnector
A network connector which uses some kind of multicast-like transport that communicates with potentially many remote brokers over a single logicalTransport
instance such as when using multicast.class
NetworkConnector
Connector class for bridging broker networks.Methods in org.apache.activemq.network that return Service Modifier and Type Method Description protected Service
DemandForwardingBridgeSupport. getControllingService()
-
Uses of Service in org.apache.activemq.network.jms
Classes in org.apache.activemq.network.jms that implement Service Modifier and Type Class Description class
DestinationBridge
A Destination bridge is used to bridge between to different JMS systemsclass
InboundQueueBridge
Create an Inbound Queue Bridge.class
InboundTopicBridge
Create an Inbound Topic Bridge.class
JmsConnector
This bridge joins the gap between foreign JMS providers and ActiveMQ As some JMS providers are still only in compliance with JMS v1.0.1 , this bridge itself aimed to be in compliance with the JMS 1.0.2 specification.class
JmsQueueConnector
A Bridge to other JMS Queue providersclass
JmsTopicConnector
A Bridge to other JMS Topic providersclass
OutboundQueueBridge
Create an Outbound Queue Bridge.class
OutboundTopicBridge
Create an Outbound Topic Bridge.class
SimpleJmsQueueConnector
class
SimpleJmsTopicConnector
A Bridge to other JMS Topic providers -
Uses of Service in org.apache.activemq.partition
Classes in org.apache.activemq.partition that implement Service Modifier and Type Class Description class
PartitionBroker
A BrokerFilter which partitions client connections over a cluster of brokers.class
ZooKeeperPartitionBroker
-
Uses of Service in org.apache.activemq.plugin
Classes in org.apache.activemq.plugin that implement Service Modifier and Type Class Description class
AbstractRuntimeConfigurationBroker
class
DiscardingDLQBroker
class
ForcePersistencyModeBroker
A Plugin which allows to force every incoming message to be PERSISTENT or NON-PERSISTENT.class
RuntimeConfigurationBroker
class
StatisticsBroker
A StatisticsBroker You can retrieve a Map Message for a Destination - or Broker containing statistics as key-value pairs The message must contain a replyTo Destination - else its ignoredclass
SubQueueSelectorCacheBroker
A plugin which allows the caching of the selector from a subscription queue. -
Uses of Service in org.apache.activemq.plugin.java
Classes in org.apache.activemq.plugin.java that implement Service Modifier and Type Class Description class
JavaRuntimeConfigurationBroker
-
Uses of Service in org.apache.activemq.pool
Classes in org.apache.activemq.pool that implement Service Modifier and Type Class Description class
JcaPooledConnectionFactory
class
PooledConnectionFactory
Add Service and Referenceable and TransportListener to @link{org.apache.activemq.jms.pool.PooledConnectionFactory}class
XaPooledConnectionFactory
Add Service and Referenceable and TransportListener to @link{org.apache.activemq.jms.pool.XaPooledConnectionFactory} -
Uses of Service in org.apache.activemq.proxy
Classes in org.apache.activemq.proxy that implement Service Modifier and Type Class Description class
ProxyConnector
-
Uses of Service in org.apache.activemq.security
Classes in org.apache.activemq.security that implement Service Modifier and Type Class Description class
AbstractAuthenticationBroker
class
AuthorizationBroker
Verifies if a authenticated user can do an operation against the broker using an authorization map.class
AuthorizationDestinationFilter
Authorizes addSubscription calls.class
JaasAuthenticationBroker
Logs a user in using JAAS.class
JaasCertificateAuthenticationBroker
A JAAS Authentication Broker that uses SSL Certificates.class
JaasDualAuthenticationBroker
A JAAS Authentication Broker that uses different JAAS domain configurations depending if the connection is over an SSL enabled Connector or not.class
SimpleAuthenticationBroker
Handles authenticating a users against a simple user name/password map. -
Uses of Service in org.apache.activemq.shiro
Classes in org.apache.activemq.shiro that implement Service Modifier and Type Class Description class
SecurityFilter
class
ShiroPlugin
-
Uses of Service in org.apache.activemq.shiro.authc
Classes in org.apache.activemq.shiro.authc that implement Service Modifier and Type Class Description class
AuthenticationFilter
TheAuthenticationFilter
enforces if authentication is required before allowing the broker filter chain to continue. -
Uses of Service in org.apache.activemq.shiro.authz
Classes in org.apache.activemq.shiro.authz that implement Service Modifier and Type Class Description class
AuthorizationFilter
TheAuthorizationFilter
asserts that actions are allowed to execute first before they are actually executed. -
Uses of Service in org.apache.activemq.shiro.env
Classes in org.apache.activemq.shiro.env that implement Service Modifier and Type Class Description class
EnvironmentFilter
An abstractBrokerFilter
that makes the ShiroEnvironment
available to subclasses. -
Uses of Service in org.apache.activemq.shiro.subject
Classes in org.apache.activemq.shiro.subject that implement Service Modifier and Type Class Description class
SubjectFilter
TheSubjectFilter
ensures a ShiroSubject
representing the client's identity is associated with every connection to the ActiveMQ Broker. -
Uses of Service in org.apache.activemq.store
Subinterfaces of Service in org.apache.activemq.store Modifier and Type Interface Description interface
MessageStore
Represents a message store which is used by the persistent implementationsinterface
PersistenceAdapter
Adapter to the actual persistence mechanism used with ActiveMQinterface
PListStore
interface
ReferenceStore
Represents a message store which is used by the persistent implementationsinterface
TopicMessageStore
A MessageStore for durable topic subscriptionsinterface
TopicReferenceStore
A MessageStore for durable topic subscriptionsinterface
TransactionStore
Represents the durable store of the commit/rollback operations taken against the broker.Classes in org.apache.activemq.store that implement Service Modifier and Type Class Description class
AbstractMessageStore
class
PersistenceAdapterFactoryBean
Creates a default persistence model using the Journal and JDBCclass
ProxyMessageStore
A simple proxy that delegates to another MessageStore.class
ProxyTopicMessageStore
A simple proxy that delegates to another MessageStore.class
SharedFileLocker
Represents an exclusive lock on a database to avoid multiple brokers running against the same logical database. -
Uses of Service in org.apache.activemq.store.jdbc
Subinterfaces of Service in org.apache.activemq.store.jdbc Modifier and Type Interface Description interface
DatabaseLocker
Deprecated.As of 5.7.0, use more generalLocker
insteadClasses in org.apache.activemq.store.jdbc that implement Service Modifier and Type Class Description class
AbstractJDBCLocker
class
DataSourceServiceSupport
A helper class which provides a factory method to create a default {@link DataSource) if one is not provided.class
DefaultDatabaseLocker
Represents an exclusive lock on a database to avoid multiple brokers running against the same logical database.class
JdbcMemoryTransactionStore
respect 2pc prepare uses local transactions to maintain prepared state xid column provides transaction flag for additions and removals a commit clears that context and completes the work a rollback clears the flag and removes the additions Essentially a prepare is an insert &| update transaction commit|rollback is an update &| removeclass
JDBCMessageStore
class
JDBCPersistenceAdapter
APersistenceAdapter
implementation using JDBC for persistence storage.class
JDBCTopicMessageStore
class
LeaseDatabaseLocker
Represents an exclusive lease on a database to avoid multiple brokers running against the same logical database. -
Uses of Service in org.apache.activemq.store.jdbc.adapter
Classes in org.apache.activemq.store.jdbc.adapter that implement Service Modifier and Type Class Description class
TransactDatabaseLocker
Represents an exclusive lock on a database to avoid multiple brokers running against the same logical database. -
Uses of Service in org.apache.activemq.store.journal
Classes in org.apache.activemq.store.journal that implement Service Modifier and Type Class Description class
JournalMessageStore
A MessageStore that uses a Journal to store it's messages.class
JournalPersistenceAdapter
An implementation ofPersistenceAdapter
designed for use with aJournal
and then check pointing asynchronously on a timeout with some other long term persistent storage.class
JournalPersistenceAdapterFactory
Factory class that can create PersistenceAdapter objects.class
JournalTopicMessageStore
A MessageStore that uses a Journal to store it's messages.class
JournalTransactionStore
-
Uses of Service in org.apache.activemq.store.kahadb
Classes in org.apache.activemq.store.kahadb that implement Service Modifier and Type Class Description class
AbstractKahaDBStore
class
KahaDBPersistenceAdapter
An implementation ofPersistenceAdapter
designed for use with KahaDB - Embedded Lightweight Non-Relational Databaseclass
KahaDBStore
class
KahaDBStore.KahaDBMessageStore
class
KahaDBTransactionStore
Provides a TransactionStore implementation that can create transaction aware MessageStore objects from non transaction aware MessageStore objects.class
MessageDatabase
class
MultiKahaDBPersistenceAdapter
An implementation ofPersistenceAdapter
that supports distribution of destinations across multiple kahaDB persistence adaptersclass
MultiKahaDBTransactionStore
class
TempKahaDBStore
class
TempKahaDBStore.KahaDBMessageStore
-
Uses of Service in org.apache.activemq.store.kahadb.plist
Classes in org.apache.activemq.store.kahadb.plist that implement Service Modifier and Type Class Description class
PListStoreImpl
-
Uses of Service in org.apache.activemq.store.kahadb.scheduler
Classes in org.apache.activemq.store.kahadb.scheduler that implement Service Modifier and Type Class Description class
JobSchedulerImpl
class
JobSchedulerStoreImpl
-
Uses of Service in org.apache.activemq.store.memory
Classes in org.apache.activemq.store.memory that implement Service Modifier and Type Class Description class
MemoryMessageStore
An implementation ofMessageStore
class
MemoryPersistenceAdapter
class
MemoryTopicMessageStore
class
MemoryTransactionStore
Provides a TransactionStore implementation that can create transaction aware MessageStore objects from non transaction aware MessageStore objects. -
Uses of Service in org.apache.activemq.thread
Classes in org.apache.activemq.thread that implement Service Modifier and Type Class Description class
Scheduler
-
Uses of Service in org.apache.activemq.transport
Subinterfaces of Service in org.apache.activemq.transport Modifier and Type Interface Description interface
CompositeTransport
interface
Transport
Represents the client side of a transport allowing messages to be sent synchronously, asynchronously and consumed.interface
TransportServer
A TransportServer asynchronously accepts {@see Transport} objects and then delivers those objects to a {@see TransportAcceptListener}.Classes in org.apache.activemq.transport that implement Service Modifier and Type Class Description class
AbstractInactivityMonitor
Used to make sure that commands are arriving periodically from the peer of the transport.class
CommandJoiner
Joins together of partial commands which were split into individual chunks of data.class
InactivityMonitor
Used to make sure that commands are arriving periodically from the peer of the transport.class
MarshallingTransportFilter
class
MutexTransport
Thread safe Transport Filter that serializes calls to and from the Transport Stack.class
ResponseCorrelator
Adds the incrementing sequence number to commands along with performing the correlation of responses to requests to create a blocking request-response semantics.class
ThreadNameFilter
The thread name filter, modifies the name of the thread during the invocation to a transport.class
TransportFilter
class
TransportLogger
This TransportFilter implementation writes output to a log as it intercepts commands / events before sending them to the following layer in the Transport stack.class
TransportServerFilter
class
TransportServerSupport
A useful base class for implementations ofTransportServer
class
TransportServerThreadSupport
A useful base class for implementations ofTransportServer
which uses a background thread to accept new connections.class
TransportSupport
A useful base class for transport implementations.class
TransportThreadSupport
A useful base class for a transport implementation which has a background reading thread.class
WebTransportServerSupport
class
WireFormatNegotiator
Negotiates the wire format with a new connectionclass
WriteTimeoutFilter
This filter implements write timeouts for socket write operations. -
Uses of Service in org.apache.activemq.transport.amqp
Classes in org.apache.activemq.transport.amqp that implement Service Modifier and Type Class Description class
AmqpInactivityMonitor
class
AmqpNioSslTransport
class
AmqpNioTransport
An implementation of theTransport
interface for using AMQP over NIOclass
AmqpTransportFilter
The AMQPTransportFilter normally sits on top of a TcpTransport that has been configured with the AmqpWireFormat and is used to convert AMQP commands to ActiveMQ commands.class
AmqpWSTransport
An AMQP based WebSocket transport implementation. -
Uses of Service in org.apache.activemq.transport.auto
Classes in org.apache.activemq.transport.auto that implement Service Modifier and Type Class Description class
AutoSslTransportServer
An SSL TransportServer.class
AutoTcpTransportServer
A TCP based implementation ofTransportServer
-
Uses of Service in org.apache.activemq.transport.auto.nio
Classes in org.apache.activemq.transport.auto.nio that implement Service Modifier and Type Class Description class
AutoNIOSSLTransportServer
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.class
AutoNIOTransport
-
Uses of Service in org.apache.activemq.transport.discovery
Subinterfaces of Service in org.apache.activemq.transport.discovery Modifier and Type Interface Description interface
DiscoveryAgent
An agent used to discover other instances of a service.Classes in org.apache.activemq.transport.discovery that implement Service Modifier and Type Class Description class
DiscoveryTransport
ATransportFilter
which uses aDiscoveryAgent
to discover remote broker instances and dynamically connect to them. -
Uses of Service in org.apache.activemq.transport.discovery.http
Classes in org.apache.activemq.transport.discovery.http that implement Service Modifier and Type Class Description class
EmbeddedJettyServer
class
HTTPDiscoveryAgent
-
Uses of Service in org.apache.activemq.transport.discovery.masterslave
Classes in org.apache.activemq.transport.discovery.masterslave that implement Service Modifier and Type Class Description class
MasterSlaveDiscoveryAgent
A static DiscoveryAgent that supports connecting to a Master / Slave tuple of brokers. -
Uses of Service in org.apache.activemq.transport.discovery.multicast
Classes in org.apache.activemq.transport.discovery.multicast that implement Service Modifier and Type Class Description class
MulticastDiscoveryAgent
ADiscoveryAgent
using a multicast address and heartbeat packets encoded using any wireformat, but openwire by default. -
Uses of Service in org.apache.activemq.transport.discovery.simple
Classes in org.apache.activemq.transport.discovery.simple that implement Service Modifier and Type Class Description class
SimpleDiscoveryAgent
A simple DiscoveryAgent that allows static configuration of the discovered services. -
Uses of Service in org.apache.activemq.transport.discovery.zeroconf
Classes in org.apache.activemq.transport.discovery.zeroconf that implement Service Modifier and Type Class Description class
ZeroconfDiscoveryAgent
-
Uses of Service in org.apache.activemq.transport.failover
Classes in org.apache.activemq.transport.failover that implement Service Modifier and Type Class Description class
FailoverTransport
A Transport that is made reliable by being able to fail over to another transport when a transport failure is detected. -
Uses of Service in org.apache.activemq.transport.fanout
Classes in org.apache.activemq.transport.fanout that implement Service Modifier and Type Class Description class
FanoutTransport
A Transport that fans out a connection to multiple brokers. -
Uses of Service in org.apache.activemq.transport.http
Classes in org.apache.activemq.transport.http that implement Service Modifier and Type Class Description class
BlockingQueueTransport
A server side HTTP based TransportChannel which processes incoming packets and adds outgoing packets onto aQueue
so that they can be dispatched by the HTTP GET requests from the client.class
HttpClientTransport
A HTTPTransport
which uses the Apache HTTP Client libraryclass
HttpInactivityMonitor
Inactivity Monitor specialization for use with HTTP based transports.class
HttpTransportServer
class
HttpTransportSupport
A useful base class for HTTP Transport implementations. -
Uses of Service in org.apache.activemq.transport.https
Classes in org.apache.activemq.transport.https that implement Service Modifier and Type Class Description class
HttpsClientTransport
class
HttpsTransportServer
-
Uses of Service in org.apache.activemq.transport.mock
Classes in org.apache.activemq.transport.mock that implement Service Modifier and Type Class Description class
MockTransport
-
Uses of Service in org.apache.activemq.transport.mqtt
Classes in org.apache.activemq.transport.mqtt that implement Service Modifier and Type Class Description class
MQTTInactivityMonitor
class
MQTTNIOSSLTransport
class
MQTTNIOTransport
An implementation of theTransport
interface for using MQTT over NIOclass
MQTTPacketIdGenerator
Manages PUBLISH packet ids for clients.class
MQTTTransportFilter
The MQTTTransportFilter normally sits on top of a TcpTransport that has been configured with the StompWireFormat and is used to convert MQTT commands to ActiveMQ commands. -
Uses of Service in org.apache.activemq.transport.multicast
Classes in org.apache.activemq.transport.multicast that implement Service Modifier and Type Class Description class
MulticastTransport
A multicast based transport. -
Uses of Service in org.apache.activemq.transport.nio
Classes in org.apache.activemq.transport.nio that implement Service Modifier and Type Class Description class
AutoInitNioSSLTransport
This transport initializes the SSLEngine and reads the first command before handing off to the detected transport.class
NIOSSLTransport
class
NIOSSLTransportServer
class
NIOTransport
An implementation of theTransport
interface using raw tcp/ip -
Uses of Service in org.apache.activemq.transport.reliable
Classes in org.apache.activemq.transport.reliable that implement Service Modifier and Type Class Description class
ReliableTransport
Deprecated. -
Uses of Service in org.apache.activemq.transport.stomp
Classes in org.apache.activemq.transport.stomp that implement Service Modifier and Type Class Description class
StompInactivityMonitor
Used to make sure that commands are arriving periodically from the peer of the transport.class
StompNIOSSLTransport
class
StompNIOTransport
An implementation of theTransport
interface for using Stomp over NIOclass
StompTransportFilter
The StompTransportFilter normally sits on top of a TcpTransport that has been configured with the StompWireFormat and is used to convert STOMP commands to ActiveMQ commands. -
Uses of Service in org.apache.activemq.transport.tcp
Classes in org.apache.activemq.transport.tcp that implement Service Modifier and Type Class Description class
SslTransport
A Transport class that uses SSL and client-side certificate authentication.class
SslTransportServer
An SSL TransportServer.class
TcpTransport
An implementation of theTransport
interface using raw tcp/ipclass
TcpTransportServer
A TCP based implementation ofTransportServer
Methods in org.apache.activemq.transport.tcp with parameters of type Service Modifier and Type Method Description void
TcpTransportServer. started(Service service)
void
TcpTransportServer. stopped(Service service)
-
Uses of Service in org.apache.activemq.transport.udp
Subinterfaces of Service in org.apache.activemq.transport.udp Modifier and Type Interface Description interface
ByteBufferPool
Represents a pool ofByteBuffer
instances.interface
CommandChannel
Classes in org.apache.activemq.transport.udp that implement Service Modifier and Type Class Description class
CommandChannelSupport
class
CommandDatagramChannel
A strategy for reading datagrams and de-fragmenting them together.class
CommandDatagramSocket
A strategy for reading datagrams and de-fragmenting them together.class
DefaultBufferPool
A default implementation ofSimpleBufferPool
which keeps a pool of direct byte buffers.class
ResponseRedirectInterceptor
class
SimpleBufferPool
A simple implementation ofByteBufferPool
which does no pooling and just creates new buffers each timeclass
UdpTransport
An implementation of theTransport
interface using raw UDPclass
UdpTransportServer
Deprecated. -
Uses of Service in org.apache.activemq.transport.vm
Classes in org.apache.activemq.transport.vm that implement Service Modifier and Type Class Description class
VMTransport
A Transport implementation that uses direct method invocations.class
VMTransportServer
Broker side of the VMTransport -
Uses of Service in org.apache.activemq.transport.ws
Subinterfaces of Service in org.apache.activemq.transport.ws Modifier and Type Interface Description interface
WSTransport
Interface for a WebSocket Transport which provide hooks that a servlet can use to pass along WebSocket data and events.Classes in org.apache.activemq.transport.ws that implement Service Modifier and Type Class Description class
AbstractMQTTSocket
class
AbstractStompSocket
Base implementation of a STOMP based WebSocket handler.class
WSTransportProxy
A proxy class that manages sending WebSocket events to the wrapped protocol level WebSocket Transport.class
WSTransportServer
Creates a web server and registers web socket server -
Uses of Service in org.apache.activemq.transport.ws.jetty9
Classes in org.apache.activemq.transport.ws.jetty9 that implement Service Modifier and Type Class Description class
MQTTSocket
class
StompSocket
Implements web socket and mediates between servlet and the broker -
Uses of Service in org.apache.activemq.transport.wss
Classes in org.apache.activemq.transport.wss that implement Service Modifier and Type Class Description class
WSSTransportServer
-
Uses of Service in org.apache.activemq.usage
Classes in org.apache.activemq.usage that implement Service Modifier and Type Class Description class
JobSchedulerUsage
Used to keep track of how much of something is being used so that a productive working set usage can be controlled.class
MemoryUsage
Used to keep track of how much of something is being used so that a productive working set usage can be controlled.class
PercentLimitUsage<T extends Usage>
class
StoreUsage
Used to keep track of how much of something is being used so that a productive working set usage can be controlled.class
SystemUsage
Holder for Usage instances for memory, store and temp files Main use case is manage memory usage.class
TempUsage
Used to keep track of how much of something is being used so that a productive working set usage can be controlled.class
Usage<T extends Usage>
Used to keep track of how much of something is being used so that a productive working set usage can be controlled. -
Uses of Service in org.apache.activemq.util
Classes in org.apache.activemq.util that implement Service Modifier and Type Class Description class
ServiceSupport
A helper class for working with services together with a useful base class for service implementations.Methods in org.apache.activemq.util with parameters of type Service Modifier and Type Method Description static void
ServiceSupport. dispose(Service service)
void
ServiceListener. started(Service service)
void
ServiceStopper. stop(Service service)
Stops the given service, catching any exceptions that are thrown.void
ServiceListener. stopped(Service service)
-
Uses of Service in org.apache.activemq.xbean
Classes in org.apache.activemq.xbean that implement Service Modifier and Type Class Description class
XBeanBrokerService
An ActiveMQ Message Broker.
-