|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Service | |
---|---|
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.ft | Helper classes for implementing fault tolerance |
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 store |
org.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 Destinations |
org.apache.activemq.broker.scheduler | |
org.apache.activemq.broker.util | Some utility Broker Plugins |
org.apache.activemq.broker.view | Broker Plugins for visualising the current system |
org.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.plugin | |
org.apache.activemq.pool | A JMS provider which pools Connection, Session and MessageProducer instances so it can be used with tools like Spring's JmsTemplate. |
org.apache.activemq.proxy | |
org.apache.activemq.security | Plugable Security Adapter framework along with default implementations such as the JAAS implementation. |
org.apache.activemq.store | The APIs which need to be implemented for persistent message stores for durable messaging |
org.apache.activemq.store.amq | The default Store implementation for ActiveMQ |
org.apache.activemq.store.jdbc | Message persistence implemented using JDBC |
org.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.kahadaptor | kaha implementation of message persistence for the broker |
org.apache.activemq.store.kahadb | |
org.apache.activemq.store.kahadb.plist | |
org.apache.activemq.store.memory | VM based implementation of message persistence |
org.apache.activemq.thread | |
org.apache.activemq.transport | The core Transport abstraction and support classes |
org.apache.activemq.transport.discovery | Discovery mechanism to discover brokers and clients. |
org.apache.activemq.transport.discovery.multicast | Discovery implementation using multicast |
org.apache.activemq.transport.discovery.rendezvous | A discovery agent using Zeroconf via the jmDNS library |
org.apache.activemq.transport.discovery.simple | Simple discovery implementation using a static list |
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 redundancy |
org.apache.activemq.transport.mock | A mock implementation of the Transport layer useful for testing |
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.usage | |
org.apache.activemq.util | Some utility classes |
org.apache.activemq.xbean | Helper classes for creating the a broker using XBean and for creating a broker within Spring. |
Uses of Service in org.apache.activemq.advisory |
---|
Classes in org.apache.activemq.advisory that implement Service | |
---|---|
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 | |
---|---|
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. |
Classes in org.apache.activemq.broker that implement Service | |
---|---|
class |
BrokerBroadcaster
Used to add listeners for Broker actions |
class |
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 lifecycle of an ActiveMQ Broker. |
class |
CompositeDestinationBroker
This broker filter handles composite destinations. |
class |
EmptyBroker
Dumb implementation - used to be overriden by listeners |
class |
ErrorBroker
Implementation of the broker where all it's methods throw an BrokerStoppedException. |
class |
InsertableMutableBrokerFilter
Inserts itself into the BrokerStack |
class |
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 Connection |
class |
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 | |
---|---|
Service[] |
BrokerService.getServices()
|
Methods in org.apache.activemq.broker with parameters of type Service | |
---|---|
void |
BrokerService.addService(Service service)
Adds a new service so that it will be started as part of the broker lifecycle |
void |
BrokerService.removeService(Service service)
|
void |
BrokerService.setServices(Service[] services)
Sets the services associated with this broker such as a MasterConnector |
Uses of Service in org.apache.activemq.broker.cluster |
---|
Classes in org.apache.activemq.broker.cluster that implement Service | |
---|---|
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.ft |
---|
Classes in org.apache.activemq.broker.ft that implement Service | |
---|---|
class |
MasterBroker
The Message Broker which passes messages to a slave |
class |
MasterConnector
Connects a Slave Broker to a Master when using Master Slave for High Availability of messages. |
Uses of Service in org.apache.activemq.broker.jmx |
---|
Subinterfaces of Service in org.apache.activemq.broker.jmx | |
---|---|
interface |
BrokerViewMBean
|
interface |
ConnectionViewMBean
|
interface |
ConnectorViewMBean
|
interface |
FTConnectorViewMBean
|
interface |
JmsConnectorViewMBean
|
interface |
NetworkBridgeViewMBean
|
interface |
NetworkConnectorViewMBean
|
interface |
ProxyConnectorViewMBean
|
Classes in org.apache.activemq.broker.jmx that implement Service | |
---|---|
class |
BrokerView
|
class |
ConnectionView
|
class |
ConnectorView
|
class |
FTConnectorView
|
class |
JmsConnectorView
|
class |
ManagedQueueRegion
|
class |
ManagedRegionBroker
|
class |
ManagedTempQueueRegion
|
class |
ManagedTempTopicRegion
|
class |
ManagedTopicRegion
|
class |
ManagedTransportConnection
A managed transport connection |
class |
ManagedTransportConnector
A managed transport connector which can create multiple managed connections as clients connect. |
class |
ManagementContext
An abstraction over JMX mbean registration |
class |
NetworkBridgeView
|
class |
NetworkConnectorView
|
class |
ProxyConnectorView
|
Uses of Service in org.apache.activemq.broker.region |
---|
Subinterfaces of Service in org.apache.activemq.broker.region | |
---|---|
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 | |
---|---|
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 | |
---|---|
interface |
PendingMessageCursor
Interface to pending message (messages awaiting disptach to a consumer) cursor |
Classes in org.apache.activemq.broker.region.cursors that implement Service | |
---|---|
class |
AbstractPendingMessageCursor
Abstract method holder for pending message (messages awaiting disptach to a consumer) cursor |
class |
AbstractStoreCursor
Store based cursor |
class |
FilePendingMessageCursor
persist pending messages pending message (messages awaiting dispatch to a consumer) cursor |
class |
StoreDurableSubscriberCursor
persist pending messages pending message (messages awaiting dispatch to a consumer) cursor |
class |
StoreQueueCursor
Store based Cursor for Queues |
class |
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 | |
---|---|
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 | |
---|---|
class |
FixedCountSubscriptionRecoveryPolicy
This implementation of SubscriptionRecoveryPolicy will keep a fixed
count of last messages. |
class |
FixedSizedSubscriptionRecoveryPolicy
This implementation of SubscriptionRecoveryPolicy will keep a fixed
amount of memory available in RAM for message history which is evicted in
time order. |
class |
LastImageSubscriptionRecoveryPolicy
This implementation of SubscriptionRecoveryPolicy will only keep the
last message. |
class |
NoSubscriptionRecoveryPolicy
This SubscriptionRecoveryPolicy disable recovery of messages. |
class |
QueryBasedSubscriptionRecoveryPolicy
This implementation of SubscriptionRecoveryPolicy will perform a user
specific query mechanism to load any messages they may have missed. |
class |
TimedSubscriptionRecoveryPolicy
This implementation of SubscriptionRecoveryPolicy 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 | |
---|---|
class |
CompositeDestinationFilter
Represents a composite Destination where send()s are replicated to
each Destination instance. |
class |
SelectorAwareVirtualTopicInterceptor
|
class |
VirtualTopicInterceptor
A Destination which implements Virtual Topic |
Uses of Service in org.apache.activemq.broker.scheduler |
---|
Classes in org.apache.activemq.broker.scheduler that implement Service | |
---|---|
class |
JobSchedulerStore
|
class |
SchedulerBroker
|
Uses of Service in org.apache.activemq.broker.util |
---|
Classes in org.apache.activemq.broker.util that implement Service | |
---|---|
class |
CommandAgent
An agent which listens to commands on a JMS destination |
class |
DestinationPathSeparatorBroker
|
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 |
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 | |
---|---|
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 | |
---|---|
interface |
NetworkBridge
Represents a network bridge interface |
Classes in org.apache.activemq.network that implement Service | |
---|---|
class |
CompositeDemandForwardingBridge
A demand forwarding bridge which works with multicast style transports where a single Transport could be communicating with multiple remote brokers |
class |
ConduitBridge
Consolidates subscriptions |
class |
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 broker |
class |
DurableConduitBridge
Consolidates subscriptions |
class |
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 logical Transport instance such as when using multicast. |
class |
NetworkConnector
|
Methods in org.apache.activemq.network that return Service | |
---|---|
protected Service |
DemandForwardingBridgeSupport.getControllingService()
|
Uses of Service in org.apache.activemq.network.jms |
---|
Classes in org.apache.activemq.network.jms that implement Service | |
---|---|
class |
DestinationBridge
A Destination bridge is used to bridge between to different JMS systems |
class |
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 1.0.1 compliant, this bridge itself aimed to be JMS 1.0.2 compliant. |
class |
JmsQueueConnector
A Bridge to other JMS Queue providers |
class |
JmsTopicConnector
A Bridge to other JMS Topic providers |
class |
OutboundQueueBridge
Create an Outbound Queue Bridge |
class |
OutboundTopicBridge
Create an Outbound Topic Bridge |
Uses of Service in org.apache.activemq.plugin |
---|
Classes in org.apache.activemq.plugin that implement Service | |
---|---|
class |
DiscardingDLQBroker
|
class |
ForcePersistencyModeBroker
A Plugin which allows to force every incoming message to be PERSISTENT or NON-PERSISTENT. |
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 ignored |
Uses of Service in org.apache.activemq.pool |
---|
Classes in org.apache.activemq.pool that implement Service | |
---|---|
class |
AmqJNDIPooledConnectionFactory
AmqJNDIPooledConnectionFactory.java Created by linus on 2008-03-07. |
class |
JcaPooledConnectionFactory
|
class |
PooledConnectionFactory
A JMS provider which pools Connection, Session and MessageProducer instances so it can be used with tools like Camel and Spring's JmsTemplate and MessagListenerContainer. |
class |
XaPooledConnectionFactory
A pooled connection factory that automatically enlists sessions in the current active XA transaction if any. |
Uses of Service in org.apache.activemq.proxy |
---|
Classes in org.apache.activemq.proxy that implement Service | |
---|---|
class |
ProxyConnector
|
Uses of Service in org.apache.activemq.security |
---|
Classes in org.apache.activemq.security that implement Service | |
---|---|
class |
AuthorizationBroker
Verifies if a authenticated user can do an operation against the broker using an authorization map. |
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.store |
---|
Subinterfaces of Service in org.apache.activemq.store | |
---|---|
interface |
MessageStore
Represents a message store which is used by the persistent implementations |
interface |
PersistenceAdapter
Adapter to the actual persistence mechanism used with ActiveMQ |
interface |
ReferenceStore
Represents a message store which is used by the persistent implementations |
interface |
ReferenceStoreAdapter
Adapter to the actual persistence mechanism used with ActiveMQ |
interface |
TopicMessageStore
A MessageStore for durable topic subscriptions |
interface |
TopicReferenceStore
A MessageStore for durable topic subscriptions |
interface |
TransactionStore
Represents the durable store of the commit/rollback operations taken against the broker. |
Classes in org.apache.activemq.store that implement Service | |
---|---|
class |
AbstractMessageStore
|
class |
ProxyMessageStore
A simple proxy that delegates to another MessageStore. |
class |
ProxyTopicMessageStore
A simple proxy that delegates to another MessageStore. |
Uses of Service in org.apache.activemq.store.amq |
---|
Classes in org.apache.activemq.store.amq that implement Service | |
---|---|
class |
AMQMessageStore
A MessageStore that uses a Journal to store it's messages. |
class |
AMQPersistenceAdapter
An implementation of PersistenceAdapter designed for use with a
Journal and then check pointing asynchronously on a timeout with some
other long term persistent storage. |
class |
AMQTopicMessageStore
A MessageStore that uses a Journal to store it's messages. |
class |
AMQTransactionStore
|
Uses of Service in org.apache.activemq.store.jdbc |
---|
Subinterfaces of Service in org.apache.activemq.store.jdbc | |
---|---|
interface |
DatabaseLocker
Represents some kind of lock service to ensure that a broker is the only master |
Classes in org.apache.activemq.store.jdbc that implement Service | |
---|---|
class |
DefaultDatabaseLocker
Represents an exclusive lock on a database to avoid multiple brokers running against the same logical database. |
class |
JDBCMessageStore
|
class |
JDBCPersistenceAdapter
A PersistenceAdapter implementation using JDBC for persistence
storage. |
class |
JDBCTopicMessageStore
|
Uses of Service in org.apache.activemq.store.jdbc.adapter |
---|
Classes in org.apache.activemq.store.jdbc.adapter that implement Service | |
---|---|
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 | |
---|---|
class |
JournalMessageStore
A MessageStore that uses a Journal to store it's messages. |
class |
JournalPersistenceAdapter
An implementation of PersistenceAdapter designed for use with a
Journal and then check pointing asynchronously on a timeout with some
other long term persistent storage. |
class |
JournalTopicMessageStore
A MessageStore that uses a Journal to store it's messages. |
class |
JournalTransactionStore
|
Uses of Service in org.apache.activemq.store.kahadaptor |
---|
Classes in org.apache.activemq.store.kahadaptor that implement Service | |
---|---|
class |
KahaMessageStore
An implementation of MessageStore which
uses a JPS Container |
class |
KahaPersistenceAdapter
|
class |
KahaReferenceStore
|
class |
KahaReferenceStoreAdapter
|
class |
KahaTopicMessageStore
|
class |
KahaTopicReferenceStore
|
class |
KahaTransactionStore
Provides a TransactionStore implementation that can create transaction aware MessageStore objects from non transaction aware MessageStore objects. |
Uses of Service in org.apache.activemq.store.kahadb |
---|
Classes in org.apache.activemq.store.kahadb that implement Service | |
---|---|
class |
KahaDBPersistenceAdapter
An implementation of PersistenceAdapter designed for use with a
Journal and then check pointing asynchronously on a timeout with some
other long term persistent storage. |
class |
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 |
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 | |
---|---|
class |
PListStore
|
Uses of Service in org.apache.activemq.store.memory |
---|
Classes in org.apache.activemq.store.memory that implement Service | |
---|---|
class |
MemoryMessageStore
An implementation of MessageStore which
uses a |
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 | |
---|---|
class |
Scheduler
|
Uses of Service in org.apache.activemq.transport |
---|
Subinterfaces of Service in org.apache.activemq.transport | |
---|---|
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 Transport objects and then
delivers those objects to a TransportAcceptListener . |
Classes in org.apache.activemq.transport that implement Service | |
---|---|
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
|
class |
ResponseCorrelator
Adds the incrementing sequence number to commands along with performing the corelation 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 of TransportServer |
class |
TransportServerThreadSupport
A useful base class for implementations of TransportServer 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 |
WireFormatNegotiator
Negotiates the wire format with a new connection |
class |
WriteTimeoutFilter
This filter implements write timeouts for socket write operations. |
Uses of Service in org.apache.activemq.transport.discovery |
---|
Subinterfaces of Service in org.apache.activemq.transport.discovery | |
---|---|
interface |
DiscoveryAgent
An agent used to discover other instances of a service. |
Classes in org.apache.activemq.transport.discovery that implement Service | |
---|---|
class |
DiscoveryTransport
A ReliableTransportChannel which uses a DiscoveryAgent to
discover remote broker instances and dynamically connect to them. |
Uses of Service in org.apache.activemq.transport.discovery.multicast |
---|
Classes in org.apache.activemq.transport.discovery.multicast that implement Service | |
---|---|
class |
MulticastDiscoveryAgent
A DiscoveryAgent using a multicast address and heartbeat packets
encoded using any wireformat, but openwire by default. |
Uses of Service in org.apache.activemq.transport.discovery.rendezvous |
---|
Classes in org.apache.activemq.transport.discovery.rendezvous that implement Service | |
---|---|
class |
RendezvousDiscoveryAgent
A DiscoveryAgent using Zeroconf
via the jmDNS library |
Uses of Service in org.apache.activemq.transport.discovery.simple |
---|
Classes in org.apache.activemq.transport.discovery.simple that implement Service | |
---|---|
class |
SimpleDiscoveryAgent
A simple DiscoveryAgent that allows static configuration of the discovered services. |
Uses of Service in org.apache.activemq.transport.failover |
---|
Classes in org.apache.activemq.transport.failover that implement Service | |
---|---|
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 | |
---|---|
class |
FanoutTransport
A Transport that fans out a connection to multiple brokers. |
Uses of Service in org.apache.activemq.transport.mock |
---|
Classes in org.apache.activemq.transport.mock that implement Service | |
---|---|
class |
MockTransport
|
Uses of Service in org.apache.activemq.transport.multicast |
---|
Classes in org.apache.activemq.transport.multicast that implement Service | |
---|---|
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 | |
---|---|
class |
NIOTransport
An implementation of the Transport interface using raw tcp/ip |
Uses of Service in org.apache.activemq.transport.reliable |
---|
Classes in org.apache.activemq.transport.reliable that implement Service | |
---|---|
class |
ReliableTransport
This interceptor deals with out of order commands together with being able to handle dropped commands and the re-requesting dropped commands. |
Uses of Service in org.apache.activemq.transport.stomp |
---|
Classes in org.apache.activemq.transport.stomp that implement Service | |
---|---|
class |
StompNIOTransport
An implementation of the Transport interface for using Stomp over NIO |
class |
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 | |
---|---|
class |
SslTransport
A Transport class that uses SSL and client-side certificate authentication. |
class |
SslTransportServer
An SSL TransportServer. |
class |
TcpTransport
An implementation of the Transport interface using raw tcp/ip |
class |
TcpTransportServer
A TCP based implementation of TransportServer |
Methods in org.apache.activemq.transport.tcp with parameters of type Service | |
---|---|
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 | |
---|---|
interface |
ByteBufferPool
Represents a pool of ByteBuffer instances. |
interface |
CommandChannel
|
Classes in org.apache.activemq.transport.udp that implement Service | |
---|---|
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 of BufferPool which keeps a pool of direct
byte buffers. |
class |
ResponseRedirectInterceptor
|
class |
SimpleBufferPool
A simple implementation of BufferPool which does no pooling and just
creates new buffers each time |
class |
UdpTransport
An implementation of the Transport interface using raw UDP |
class |
UdpTransportServer
A UDP based implementation of TransportServer |
Uses of Service in org.apache.activemq.transport.vm |
---|
Classes in org.apache.activemq.transport.vm that implement Service | |
---|---|
class |
VMTransport
A Transport implementation that uses direct method invocations. |
class |
VMTransportServer
Broker side of the VMTransport |
Uses of Service in org.apache.activemq.usage |
---|
Classes in org.apache.activemq.usage that implement Service | |
---|---|
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 |
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 | |
---|---|
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 | |
---|---|
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 | |
---|---|
class |
XBeanBrokerService
An ActiveMQ Message Broker. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |