Package | Description |
---|---|
org.mule |
The Mule implementation of the Universal Message Objects(tm) API specification.
|
org.mule.agent |
Admin components and Agents used to control and Monitor Mule
|
org.mule.api |
The Universal Message Object(tm) API provides a way for components to interact without needing to know about the protocol or delivery mechanisms of information passed between them
|
org.mule.api.agent | |
org.mule.api.component | |
org.mule.api.context |
Manager APIs, including the UMOManager, agent and server event interfaces
|
org.mule.api.lifecycle |
Lifecycle interfaces for all UMOcomponents.
|
org.mule.api.model |
Contains the interfaces for the Model and supporting objects such as the CompoenntResolver, EntryPointResolver, etc.
|
org.mule.api.object | |
org.mule.api.registry | |
org.mule.api.routing |
Interfaces that define inbound and outbound routing API.
|
org.mule.api.service | |
org.mule.api.transport |
Contains the interfaces that comprise a provider implementation.
|
org.mule.component | |
org.mule.component.simple |
A collection of simple mule components that can be useful to simplify configuration while testing.
|
org.mule.config.spring |
Support claases for Load Mule from Spring.
|
org.mule.config.spring.util | |
org.mule.config.support | |
org.mule.context.notification |
Internal server notification types fired via the MuleManager.
|
org.mule.model | |
org.mule.model.direct | |
org.mule.model.pipeline | |
org.mule.model.seda | |
org.mule.module.client |
Simple interface for Mule clients to send and receive events from local or remote Mule Servers.
|
org.mule.module.client.remoting | |
org.mule.module.management.agent |
Management agents including agents for Jdmk, MX4J, and Log4J
|
org.mule.module.xml.expression | |
org.mule.module.xml.routing | |
org.mule.object | |
org.mule.registry | |
org.mule.routing |
Defines the core routing patterns supported by mule.
|
org.mule.routing.inbound |
Inbound router implementation as described in the Enterprise Integration Patterns book.
|
org.mule.routing.nested | |
org.mule.routing.outbound |
Outbound router implementation as described in the Enterprise Integration Patterns book.
|
org.mule.routing.response |
Response router implementations that enable asynchronous event processing in request /response messaging requests.
|
org.mule.service | |
org.mule.transport |
Contains Abstract classes providing common functionality for all Mule providers.
|
org.mule.transport.bpm | |
org.mule.transport.ejb | |
org.mule.transport.http |
Provides http transport including proxy support.
|
org.mule.transport.http.components | |
org.mule.transport.jms |
Provides Jms transport connectivity with support for all Jms features.
|
org.mule.transport.jms.activemq |
Provides Jms connectivity with ActiveMQ-specific workarounds and improvements.
|
org.mule.transport.jms.weblogic |
Provides Jms connectivity with Weblogic-specific workarounds and improvements.
|
org.mule.transport.jms.websphere |
Provides Jms connectivity with Websphere-specific workarounds and improvements.
|
org.mule.transport.jnp | |
org.mule.transport.multicast |
IP multicast connectivity for Mule.
|
org.mule.transport.quartz | |
org.mule.transport.rmi | |
org.mule.transport.servlet | |
org.mule.transport.soap.component | |
org.mule.transport.ssl |
Provides tcp connectivity over Ssl for Mule.
|
org.mule.transport.stdio | |
org.mule.transport.tcp |
Provides tcp connectivity for Mule.
|
org.mule.transport.udp |
Provides Udp connectivity for Mule.
|
org.mule.transport.vm |
A connector implementation allowing events to be passed between Mule sessions via in-memory queues.
|
org.mule.util.monitor |
Various resource monitor implementations.
|
org.mule.util.pool | |
org.mule.util.store | |
org.mule.work |
A javax.resource.spi.WorkManager implementation.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAgent
Implements common methods for all Agents.
|
class |
AbstractExceptionListener
AbstractExceptionListener is a base implementation that custom
Exception Listeners can override. |
class |
DefaultExceptionStrategy
DefaultExceptionStrategy provides a default exception handling
strategy. |
class |
DefaultMuleContext |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNotificationLoggerAgent
AbstractNotificationLoggerAgent Receives Mule server notifications
and logs them and can optionally route them to an endpoint. |
class |
ConfigScannerAgent
EXPERIMENTAL!!!
This agent scans a defined directory for dropped configuration files.
|
class |
EndpointNotificationLoggerAgent
EndpointAbstractEventLoggerAgent will forward server notifications
to a configurered endpoint uri. |
class |
Log4jNotificationLoggerAgent
AbstractNotificationLoggerAgent Receives Mule server notifications
and logs them and can optionally route them to an endpoint |
Modifier and Type | Interface and Description |
---|---|
interface |
MuleContext |
Modifier and Type | Interface and Description |
---|---|
interface |
Agent
Agent is a server plugin that can be initialised, started and
destroyed along with the UMOManager itself. |
Modifier and Type | Interface and Description |
---|---|
interface |
Component
A
Component is a invoked by a Service for each incoming
MuleEvent routed on by the InboundRouterCollection . |
interface |
JavaComponent
JavaComponent is a Java Component implementation used to
invoke Java component implementations. |
interface |
LifecycleAdapter
LifecycleAdapter is a wrapper around a pojo service that adds Lifecycle methods to the pojo. |
Modifier and Type | Interface and Description |
---|---|
interface |
WorkManager
WorkManager extends the standard JCA WorkManager with lifecycle
methods and util.concurrent bridging. |
Modifier and Type | Interface and Description |
---|---|
interface |
Lifecycle
DefaultLifecyclePhase adds lifecycle methods start ,
stop and dispose . |
Constructor and Description |
---|
DisposeException(Message message,
Disposable component) |
DisposeException(Message message,
Throwable cause,
Disposable component) |
DisposeException(Throwable cause,
Disposable component) |
Modifier and Type | Interface and Description |
---|---|
interface |
Model
The
Model encapsulates and manages the runtime behaviour of a
Mule Server instance. |
Modifier and Type | Interface and Description |
---|---|
interface |
ObjectFactory
ObjectFactory is a generic Factory interface. |
Modifier and Type | Interface and Description |
---|---|
interface |
Registry |
Modifier and Type | Interface and Description |
---|---|
interface |
InboundRouter
InboundRouter defines an interface for an inbound Message
router. |
interface |
InboundRouterCollection
DefaultInboundRouterCollection manages a collection of inbound routers. |
interface |
NestedRouter |
interface |
NestedRouterCollection
NestedRouterCollection manages a collection of nested routers. |
interface |
OutboundRouter
OutboundRouter is used to control outbound routing behaviour for
an event. |
interface |
OutboundRouterCollection
OutboundRouterCollection is responsible for holding all outbound routers for a service service. |
interface |
ResponseRouter
ResponseRouter is a router that handles response flow. |
interface |
ResponseRouterCollection
ResponseRouterCollection is a router that can be used to control
how the response in a request/response message flow is created. |
interface |
Router
Router is a base interface for all routers. |
interface |
RouterCollection
RouterCollection defines the interface for a MessageRouter that
manages more than one router. |
Modifier and Type | Interface and Description |
---|---|
interface |
Service
Service is the internal representation of a Mule Managed service. |
Modifier and Type | Interface and Description |
---|---|
interface |
Connector
Connector is the mechanism used to connect to external systems
and protocols in order to send and receive data. |
interface |
MessageDispatcher
Combine
MessageDispatching with
various lifecycle methods for the actual instances doing message sending. |
interface |
MessageReceiver
MessageReceiver is used to receive data from an external system. |
interface |
MessageRequester
Combine
MessageRequesting with
various lifecycle methods for the actual instances doing message sending. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractComponent
|
class |
AbstractJavaComponent
Abstract implementation of JavaComponent adds JavaComponent specific's:
EntryPointResolverSet , NestedRouterCollection and
ObjectFactory . |
class |
DefaultJavaComponent
Default implementation of
JavaComponent . |
class |
DefaultLifecycleAdapter
DefaultLifecycleAdapter provides lifecycle methods for all Mule
managed components. |
class |
PooledJavaComponent
PooledJavaComponent implements pooling. |
protected class |
PooledJavaComponent.LifeCycleAdaptorFactory
LifeCycleAdaptorFactory wraps the Component' s
ObjectFactory . |
class |
SimpleCallableJavaComponent
Simple
JavaComponent implementation to be used when
LifecycleAdapter is not required because i) the object instance implements
Callable and so entry-point resolution is required and ii) nested-routers
are not used.An ObjectFactory can be set but must return object
instances that implement Callable . |
Modifier and Type | Class and Description |
---|---|
class |
PassThroughComponent
PassThroughComponent will simply return the payload back as the
result. |
Modifier and Type | Class and Description |
---|---|
class |
SpringRegistry |
Modifier and Type | Class and Description |
---|---|
class |
SpringBeanLookup
This is an implementation of the ObjectFactory interface which simply delegates to
the Spring ApplicationContext.
|
Modifier and Type | Class and Description |
---|---|
class |
InheritedModel
TODO
|
Modifier and Type | Class and Description |
---|---|
class |
ServerNotificationManager
A reworking of the event manager that allows efficient behaviour without global on/off
switches in the config.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractModel
MuleModel is the default implementation of the Model. |
Modifier and Type | Class and Description |
---|---|
class |
DirectModel |
class |
DirectService
A direct service invokes the service service directly without any threading, even
when the invocation is asynchronous
|
Modifier and Type | Class and Description |
---|---|
class |
PipelineModel |
class |
PipelineService |
Modifier and Type | Class and Description |
---|---|
class |
SedaModel
A mule service service model that uses Seda principals to achieve high
throughput by Quing events for compoonents and processing them concurrently.
|
class |
SedaService
A Seda service runs inside a Seda Model and is responsible for managing a Seda
Queue and thread pool for a Mule sevice service.
|
Modifier and Type | Class and Description |
---|---|
class |
MuleClient
MuleClient is a simple interface for Mule clients to send and
receive events from a Mule Server. |
class |
RemoteDispatcher
RemoteDispatcher is used to make and receive requests to a remote
Mule instance. |
Modifier and Type | Class and Description |
---|---|
class |
RemoteDispatcherAgent
RemoteDispatcherAgent manages the server endpoint that receives Admin and
remote client requests |
Modifier and Type | Class and Description |
---|---|
class |
DefaultJmxSupportAgent |
class |
JdmkAgent
JdmkAgent configures an Jdmk Http Adaptor for Jmx management,
statistics and configuration viewing of a Mule instance. |
class |
JmxAgent
JmxAgent registers Mule Jmx management beans with an MBean server. |
class |
JmxServerNotificationAgent
An agent that propergates Mule Server notifications to Jmx.
|
class |
Log4jAgent
Log4jAgent exposes the configuration of the Log4J instance running
in Mule for Jmx management |
class |
Mx4jAgent
Mx4jAgent configures an Mx4J Http Adaptor for Jmx management,
statistics and configuration viewing of a Mule instance. |
class |
RmiRegistryAgent
Binds to an existing RMI registry or creates a new one on a defined URI.
|
class |
WrapperManagerAgent
This agent integrates Java Service Wrapper into Mule.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractXPathExpressionEvaluator
Provides a base class for XPath property extractors.
|
class |
BeanPayloadExpressionEvaluator
TODO
|
class |
XPathExpressionEvaluator
Will select the text of a single node based on the property name
|
Modifier and Type | Class and Description |
---|---|
class |
FilteringXmlMessageSplitter
FilteringXmlMessageSplitter will split a DOM4J document into nodes
based on the "splitExpression" property. |
class |
RoundRobinXmlSplitter
This router will split the Xml message into parts based on the xpath expression
and route each new event to the endpoints on the router, one after the other.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractObjectFactory
Creates object instances based on the class and sets any properties.
|
class |
JndiObjectFactory |
class |
PrototypeObjectFactory
Creates a new instance of the object on each call.
|
class |
SingletonObjectFactory
Creates an instance of the object once and then always returns the same instance.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRegistry |
class |
ExpressionEvaluatorProcessor
Registers ExpressionEvaluators with the
ExpressionEvaluatorManager so that they will
be resolved at run-time. |
class |
TransientRegistry |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRouter
Implements the shared methods that all routers have.
|
class |
AbstractRouterCollection
AbstractRouterCollection provides common method implementations of
router collections for in and outbound routers. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEventAggregator
AbstractEventAggregator will aggregate a set of messages into a
single message. |
class |
AbstractEventResequencer
AbstractEventResequencer is used to receive a set of events,
resequence them and forward them on to their destination |
class |
CorrelationAggregator
CorrelationAggregator uses the CorrelationID and
CorrelationGroupSize properties of the MuleMessage to manage
message groups. |
class |
CorrelationEventResequencer
CorrelationEventResequencer is used to resequence events according
to their dispatch sequence in the correlation group. |
class |
DefaultInboundRouterCollection
DefaultInboundRouterCollection is a collection of routers that will be
invoked when an event is received. |
class |
ForwardingConsumer
ForwardingConsumer is used to forward an incoming event over
another transport without invoking a service. |
class |
IdempotentReceiver
IdempotentReceiver ensures that only unique messages are received by a
service. |
class |
IdempotentSecureHashReceiver
IdempotentSecureHashReceiver ensures that only unique messages are
received by a service. |
class |
InboundPassThroughRouter
InboundPassThroughRouter allows inbound routing over all
registered endpoints without any filtering. |
class |
MessageChunkingAggregator |
class |
SelectiveConsumer
SelectiveConsumer is an inbound router used to filter out unwanted
events. |
class |
SimpleCollectionAggregator
This router will return all aggregated events as a
MuleMessageCollection . |
class |
WireTap
An inbound router that can forward every message to another destination as defined
in the "endpoint" property.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultNestedRouter |
class |
DefaultNestedRouterCollection
TODO
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMessageSplitter
AbstractMessageSplitter is an outbound Message Splitter used to split
the contents of a received message into sub parts that can be processed by other
components. |
class |
AbstractOutboundRouter
AbstractOutboundRouter is a base router class that tracks
statistics about message processing through the router. |
class |
AbstractRecipientList
AbstractRecipientList is used to dispatch a single event to
multiple recipients over the same transport. |
class |
ChainingRouter
ChainingRouter is used to pass a Mule event through multiple
endpoints using the result of the first as the input for the second. |
class |
DefaultOutboundRouterCollection
DefaultOutboundRouterCollection is a container of routers. |
class |
EndpointSelector
EndpointSelector selects the outgoing endpoint based on a
an expression evaluator ("header:endpoint" by default). |
class |
ExceptionBasedRouter
ExceptionBasedRouter Will send the current event to the first
endpoint that doesn't throw an exception. |
class |
FilteringListMessageSplitter
FilteringListMessageSplitter accepts a List as a message payload
then routes list elements as messages over an endpoint where the endpoint's filter
accepts the payload. |
class |
FilteringOutboundRouter
FilteringRouter is a router that accepts events based on a filter
set. |
class |
MessageChunkingRouter
A router that breaks up the current message onto smaller parts and sends them to the
same destination.
|
class |
MulticastingRouter
MulticastingRouter will broadcast the current message to every endpoint
registed with the router. |
class |
OutboundPassThroughRouter
OutboundPassThroughRouter allows outbound routing over a single
endpoint without any filtering. |
class |
StaticRecipientList
StaticRecipientList is used to dispatch a single event to multiple
recipients over the same transport. |
class |
TemplateEndpointRouter
The TemplateEndpointRouter allows endpoints to be altered at runtime based on
properties set on the current event or fallback values set on the endpoint properties.
|
class |
TransformerRouter
Simply applies a transformer before continuing on to the next router.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractResponseAggregator
AbstractResponseAggregator provides a base class for implementing
response aggregator routers. |
class |
AbstractResponseRouter
AbstractResponseRouter is a base class for all Response Routers |
class |
DefaultResponseRouterCollection
DefaultResponseRouterCollection is a router that can be used to control how
the response in a request/response message flow is created. |
class |
ResponseCorrelationAggregator
ResponseCorrelationAggregator Correlates one or more events on a
response flow using the Correlation Id to group events. |
class |
SimpleCollectionResponseAggregator
A simple aggregator that will keep collecting events until a timeout is reached.
|
class |
SingleResponseRouter
Handles single event responses from a replyTo address.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractService
A base implementation for all UMOComponents in Mule
|
class |
DefaultServiceExceptionStrategy
DefaultServiceExceptionStrategy is the default exception handler
for components. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractConnector
AbstractConnector provides base functionality for all connectors
provided with Mule. |
class |
AbstractJndiConnector
This class acts as common baseclass for both Rmi & EjbConnector Resolves Jndi root for connector usage
|
class |
AbstractMessageDispatcher
Provide a default dispatch (client) support for handling threads lifecycle and validation.
|
class |
AbstractMessageReceiver
AbstractMessageReceiver provides common methods for all Message
Receivers provided with Mule. |
class |
AbstractMessageRequester
Provide a default dispatch (client) support for handling threads lifecycle and validation.
|
class |
AbstractPollingMessageReceiver
AbstractPollingMessageReceiver implements a base class for polling
message receivers. |
class |
TransactedPollingMessageReceiver
The TransactedPollingMessageReceiver is an abstract receiver that handles polling
and transaction management.
|
class |
UnsupportedMessageDispatcher |
class |
UnsupportedMessageRequester |
Modifier and Type | Class and Description |
---|---|
class |
ProcessComponent |
class |
ProcessConnector
The BPM provider allows Mule events to initiate and/or advance processes in an
external or embedded Business Process Management System (BPMS).
|
class |
ProcessMessageDispatcher
Initiates or advances a workflow process from an outgoing Mule event.
|
class |
ProcessMessageReceiver
Generates an incoming Mule event from an executing workflow process.
|
Modifier and Type | Class and Description |
---|---|
class |
EjbConnector
Provides Connection configurstion for EJB endpoints
|
class |
EjbMessageDispatcher
Invokes a method on an EJB object stored in Jndi.
|
class |
EjbMessageReceiver
Will repeatedly call a method on an EJB object.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpClientMessageDispatcher
HttpClientMessageDispatcher dispatches Mule events over HTTP. |
class |
HttpClientMessageRequester
Rquests Mule events over HTTP.
|
class |
HttpConnector
HttpConnector provides a way of receiving and sending http requests
and responses. |
class |
HttpMessageReceiver
HttpMessageReceiver is a simple http server that can be used to
listen for HTTP requests on a particular port. |
class |
HttpPollingConnector
The HttpPollingConnectors allows for inbound Http endpoints to be configured with an address which it shall use
to poll for a result.
|
class |
HttpsConnector
HttpsConnector provides Secure http connectivity on top of what is already provided with the
Mule HttpConnector . |
class |
HttpsMessageReceiver |
class |
HttpsPollingConnector
HttpsPollingConnector provides Secure http connectivity on top of what is already provided with the
Mule HttpPollingConnector . |
class |
PollingHttpMessageReceiver
Will poll an http URL and use the response as the input for a service request.
|
Modifier and Type | Class and Description |
---|---|
class |
RestServiceWrapper
This service can used to proxy REST style services as local Mule Components.
|
Modifier and Type | Class and Description |
---|---|
class |
JmsConnector
JmsConnector is a JMS 1.0.2b compliant connector that can be used
by a Mule endpoint. |
class |
JmsMessageDispatcher
JmsMessageDispatcher is responsible for dispatching messages to JMS
destinations. |
class |
JmsMessageReceiver
Registers a single JmsMessage listener but uses a thread pool to process incoming
messages
|
class |
JmsMessageRequester
JmsMessageDispatcher is responsible for dispatching messages to JMS
destinations. |
class |
MultiConsumerJmsMessageReceiver
This is an experimental rework of the
transacted.message.receiver
(it may work with non-transacted sessions as well,
just hasn't been tested and load-tested yet. |
class |
SingleJmsMessageReceiver
Registers a single Jms MessageListener for an endpoint
|
class |
TransactedSingleResourceJmsMessageReceiver |
class |
XaTransactedJmsMessageReceiver |
Modifier and Type | Class and Description |
---|---|
class |
ActiveMQJmsConnector
ActiveMQ 4.x-specific JMS connector.
|
class |
ActiveMQXAJmsConnector |
Modifier and Type | Class and Description |
---|---|
class |
WeblogicJmsConnector
Weblogic-specific JMS connector.
|
Modifier and Type | Class and Description |
---|---|
class |
WebsphereJmsConnector
Websphere-specific JMS connector.
|
class |
WebsphereTransactedJmsMessageReceiver |
Modifier and Type | Class and Description |
---|---|
class |
JnpConnector
JnpConnector uses the Java Naming protocol to bind to remote
objects |
Modifier and Type | Class and Description |
---|---|
class |
MulticastConnector
MulticastConnector can dispatch mule events using ip multicasting |
class |
MulticastMessageReceiver |
class |
MulticastMessageReceiver.MulticastWorker |
Modifier and Type | Class and Description |
---|---|
class |
QuartzConnector
Creates a connection to a Quartz scheduler.
|
class |
QuartzMessageDispatcher
Can schedule a Job with the Quartz scheduler.
|
class |
QuartzMessageReceiver
Listens for Quartz sheduled events using the Receiver Job and fires events to the
service associated with this receiver.
|
Modifier and Type | Class and Description |
---|---|
class |
RmiCallbackMessageReceiver
TODO
|
class |
RmiConnector
RmiConnector can bind or send to a given RMI port on a given host. |
class |
RmiMessageDispatcher
RmiMessageDispatcher will send transformed mule events over
RMI-JRMP. |
class |
RmiMessageReceiver
Will repeatedly call a method on a Remote object.
|
Modifier and Type | Class and Description |
---|---|
class |
ServletConnector
ServletConnector is a channel adapter between Mule and a servlet
engine. |
class |
ServletMessageReceiver
ServletMessageReceiver is a receiver that is invoked from a Servlet
when an event is received. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractWebServiceWrapperComponent |
Modifier and Type | Class and Description |
---|---|
class |
SslConnector
SslConnector provides a connector for SSL connections. |
class |
SslMessageReceiver |
protected class |
SslMessageReceiver.SslWorker |
class |
TlsConnector
TlsConnector Provides TLS connections |
Modifier and Type | Class and Description |
---|---|
class |
PromptStdioConnector
PromptStdioConnector connects to the System streams in and out by
default and add some basic fuctionality for writing out prompt messages. |
class |
StdioConnector
StdioConnector can send and receive Mule events over IO streams. |
class |
StdioMessageDispatcher
StdioMessageDispatcher is a simple stream dispatcher that obtains
a stream from the Stream Connector to write to. |
class |
StdioMessageReceiver
StdioMessageReceiver is a listener for events from Mule components
which then simply passes the events on to the target components. |
Modifier and Type | Class and Description |
---|---|
class |
TcpConnector
TcpConnector can bind or sent to a given TCP port on a given host. |
class |
TcpMessageDispatcher
Send transformed Mule events over TCP.
|
class |
TcpMessageReceiver
TcpMessageReceiver acts like a TCP server to receive socket
requests. |
protected class |
TcpMessageReceiver.TcpWorker |
class |
TcpMessageRequester
Request transformed Mule events from TCP.
|
Modifier and Type | Class and Description |
---|---|
class |
UdpConnector
UdpConnector can send and receive Mule events as Datagram packets. |
class |
UdpMessageDispatcher
UdpMessageDispatcher is responsible for dispatching MuleEvents as
UDP packets on the network |
class |
UdpMessageReceiver
UdpMessageReceiver receives UDP message packets. |
protected class |
UdpMessageReceiver.UdpWorker |
class |
UdpMessageRequester
Responsible for requesting MuleEvents as UDP packets on the network
|
Modifier and Type | Class and Description |
---|---|
class |
VMConnector
VMConnector A simple endpoint wrapper to allow a Mule service to
be accessed from an endpoint |
class |
VMMessageDispatcher
VMMessageDispatcher is used for providing in memory interaction
between components. |
class |
VMMessageReceiver
VMMessageReceiver is a listener for events from a Mule service which then simply passes
the events on to the target service. |
class |
VMMessageRequester
VMMessageDispatcher is used for providing in memory interaction
between components. |
Modifier and Type | Class and Description |
---|---|
class |
ExpiryMonitor
ExpiryMonitor can monitor objects beased on an expiry time and can
invoke a callback method once the object time has expired. |
Modifier and Type | Interface and Description |
---|---|
interface |
LifecyleEnabledObjectPool
An ObjectPool that allows Start and Stop life-cycle to be propagated pooled
object.
|
interface |
ObjectPool
ObjectPool is a simple pooling interface for objects |
Modifier and Type | Class and Description |
---|---|
class |
CommonsPoolObjectPool
CommonsPoolProxyPool is an implementation of ObjectPool
that internally uses the commons-pool GenericObjectPool and uses a
ObjectFactory for creating new pooled instances. |
class |
DefaultLifecycleEnabledObjectPool
A LifecyleEnabledObjectPool implementation for pooling
LifecycleAdapter
instances for implementations of JavaComponent that require
LifecycleAdapter pooling such as PooledJavaComponent . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMonitoredObjectStore
TODO
|
class |
InMemoryObjectStore
InMemoryObjectStore implements an optionally bounded
in-memory store for message IDs with periodic expiry of old entries. |
class |
TextFileObjectStore
A Simple object store that stores String objects by key to a text file.
|
Modifier and Type | Class and Description |
---|---|
class |
MuleWorkManager
MuleWorkManager is a JCA Work manager implementation used to manage
thread allocation for Mule components and connectors. |
Copyright © 2003–2013 MuleSource, Inc.. All rights reserved.