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.endpoint |
Endpoint 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.security |
Security API for authentication and authorisation.
|
org.mule.api.service | |
org.mule.api.transformer |
Contains the interfaces for transformers and exceptions for the UMO Transformer API.
|
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.bootstrap | |
org.mule.config.spring |
Support claases for Load Mule from Spring.
|
org.mule.config.spring.factories | |
org.mule.config.spring.util | |
org.mule.config.support | |
org.mule.endpoint |
Implemtation of Mule endpoint uris.
|
org.mule.lifecycle | |
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.jaas | |
org.mule.module.jaas.filters | |
org.mule.module.management.agent |
Management agents including agents for Jdmk, MX4J, and Log4J
|
org.mule.module.management.mbean |
Jmx Management beans for mule components, the model and the Mule server.
|
org.mule.module.xml.routing | |
org.mule.module.xml.transformer |
Xml and Xslt Transformer implementations.
|
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.security |
Core security implementation including the mule security manager and encryption types
|
org.mule.security.filters |
Core sercurity filter types.
|
org.mule.service | |
org.mule.transaction.lookup | |
org.mule.transformer |
Provides the default transformer base implementations for Mule including compression and encryption support.
|
org.mule.transformer.codec |
Transformers for Base64, UC and UU encoding/decoding.
|
org.mule.transformer.compression |
Transformers for compressing and uncompressing message payloads.
|
org.mule.transformer.encryption |
Transformers for encrypting and decrypting message payloads.
|
org.mule.transformer.simple |
Basic transformer implementations.
|
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.http.transformers | |
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.transformers |
Contains transformers to convert to and from different javax.jms.Message types
|
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 | |
org.mule.transport.soap.component | |
org.mule.transport.soap.transformers | |
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.pool | |
org.mule.util.store |
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 |
EncryptionStrategy
EncryptionStrategy can be used to provide different types of
Encryption strategy objects. |
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 |
EndpointURI
EndpointURI is used to determine how a message is sent or
received. |
Modifier and Type | Interface and Description |
---|---|
interface |
Lifecycle
DefaultLifecyclePhase adds lifecycle methods start ,
stop and dispose . |
Constructor and Description |
---|
InitialisationException(Message message,
Initialisable component) |
InitialisationException(Message message,
Throwable cause,
Initialisable component) |
InitialisationException(Throwable cause,
Initialisable component) |
RecoverableException(Message message,
Initialisable object) |
RecoverableException(Message message,
Initialisable object,
Throwable cause) |
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 |
EndpointSecurityFilter
EndpointSecurityFilter is a base filter for secure filtering of
inbound and outbout event flow |
interface |
SecurityManager
SecurityManager is responsible for managing one or more
security providers. |
interface |
SecurityProvider
SecurityProvider is a target security provider thsat actually
does the work of authenticating credentials and populating the Authentication
object. |
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 |
BaseTransformer
Transformer can be chained together to covert message payloads from one
object type to another. |
interface |
StreamingTransformer
TODO
|
interface |
Transformer
Transformer can be chained together to covert message payloads
from one object type to another. |
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 |
MessageReceiver
MessageReceiver is used to receive data from an external system. |
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. |
class |
StaticComponent
A service that will return a static data object as a result.
|
Modifier and Type | Class and Description |
---|---|
class |
SimpleRegistryBootstrap
This object will load objects defined in a file called
registry-bootstrap.properties into the local registry. |
Modifier and Type | Class and Description |
---|---|
class |
SpringRegistry |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEndpointFactoryBean
Abstract spring FactoryBean used to creating endpoints via spring.
|
class |
EndpointFactoryBean
Endpoint factory bean which uses type attribute to determine endpoint type (Used by 1to2migration module)
|
class |
InboundEndpointFactoryBean
Spring FactoryBean used to create concrete instances of inbound endpoints
|
class |
OutboundEndpointFactoryBean
Spring FactoryBean used to create concrete instances of outbound endpoints
|
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 |
MuleEndpointURI
MuleEndpointURI is used to determine how a message is sent of
received. |
Constructor and Description |
---|
AlreadyInitialisedException(String name,
Initialisable object) |
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 |
AbstractEventTransformer
AbstractEventTransformer adds support for adding method details to
the result message. |
class |
EventObjectTransformer
EventObjectTransformer converts a
java.util.EventObject into a DefaultMuleMessage . |
Modifier and Type | Class and Description |
---|---|
class |
RemoteDispatcherAgent
RemoteDispatcherAgent manages the server endpoint that receives Admin and
remote client requests |
class |
RemoteDispatcherComponent
RemoteDispatcherComponent is a MuleManager interal server component
responsible for receiving remote requests and dispatching them locally. |
Modifier and Type | Class and Description |
---|---|
class |
JaasSimpleAuthenticationProvider
This is the Provider for Mule's Jaas Security.
|
Modifier and Type | Class and Description |
---|---|
class |
JaasSecurityFilter |
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 | Interface and Description |
---|---|
interface |
ConnectorServiceMBean |
Modifier and Type | Class and Description |
---|---|
class |
ConnectorService |
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 |
AbstractXmlTransformer
AbstractXmlTransformer offers some XSLT transform on a DOM (or
other XML-ish) object. |
class |
AbstractXStreamTransformer
AbstractXStreamTransformer is a base class for all XStream based
transformers. |
class |
DomDocumentToXml
DomDocumentToXml Transform a org.w3c.dom.Document to XML String |
class |
JXPathExtractor
The JXPathExtractor is a simple transformer that evaluates an xpath expression
against the given bean and that returns the result.
|
class |
ObjectToXml
ObjectToXml converts any object to XML using Xstream. |
class |
XmlPrettyPrinter |
class |
XmlToDomDocument
XmlToDomDocument transforms a XML String to org.w3c.dom.Document. |
class |
XmlToObject
XmlToObject converts xml created by the ObjectToXml transformer in to a
java object graph. |
class |
XmlToOutputHandler |
class |
XmlToXMLStreamReader |
class |
XsltTransformer
XsltTransformer performs an XSLT transform on a DOM (or other XML-ish)
object. |
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 |
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 |
AbstractEndpointSecurityFilter
AbstractEndpointSecurityFilter provides basic initialisation for
all security filters, namely configuring the SecurityManager for this instance |
class |
AbstractJCEEncryptionStrategy
A JCE based encryption strategy.
|
class |
AbstractNamedEncryptionStrategy |
class |
MuleSecurityManager
MuleSecurityManager is a default implementation security manager
for a Mule instance. |
class |
PasswordBasedEncryptionStrategy
Provides password-based encryption using JCE.
|
class |
SecretKeyEncryptionStrategy
SecretKey based encryption using JCE.
|
Modifier and Type | Class and Description |
---|---|
class |
MuleEncryptionEndpointSecurityFilter
MuleEncryptionEndpointSecurityFilter provides password-based
encryption |
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 |
GenericTransactionManagerLookupFactory
A factory performing a JNDI lookup for TransactionManager.
|
class |
JBossTransactionManagerLookupFactory |
class |
JRunTransactionManagerLookupFactory |
class |
Resin3TransactionManagerLookupFactory |
class |
WeblogicTransactionManagerLookupFactory |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDiscoverableTransformer |
class |
AbstractMessageAwareTransformer
AbstractMessageAwareTransformer is a transformer that has a reference
to the current message. |
class |
AbstractTransformer
AbstractTransformer is a base class for all transformers. |
class |
NoActionTransformer
NoActionTransformer doesn't do any transformation on the source
object and returns the source as the result. |
class |
TransformerCollection
TODO
|
class |
TransformerTemplate
TODO
|
Modifier and Type | Class and Description |
---|---|
class |
Base64Decoder
Base64Encoder transforms Base64 encoded data into strings or byte
arrays. |
class |
Base64Encoder
Base64Encoder transforms strings or byte arrays into Base64 encoded
string. |
class |
XmlEntityDecoder
Decodes a String or byte[] containing XML entities
|
class |
XmlEntityEncoder
Encodes a string with XML entities
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCompressionTransformer
AbstractCompressionTransformer is a base class for all transformers
that can compress or uncompress data when they performa message transformation. |
class |
GZipCompressTransformer
GZipCompressTransformer is a transformer compressing objects into
byte arrays. |
class |
GZipUncompressTransformer
GZipCompressTransformer will uncompress a byte[] or InputStream |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEncryptionTransformer
EncryptionTransformer will transform an array of bytes or string
into an encrypted array of bytes |
class |
DecryptionTransformer
EncryptionTransformer will transform an encrypted array of bytes or
string into an decrypted array of bytes |
class |
EncryptionTransformer
EncryptionTransformer will transform an array of bytes or string
into an encrypted array of bytes |
Modifier and Type | Class and Description |
---|---|
class |
AutoTransformer
A transformer that uses the transform discovery mechanism to convert the message payload.
|
class |
ByteArrayToHexString
Converts a Byte array to a Hex String.
|
class |
ByteArrayToMuleMessage
TODO
|
class |
ByteArrayToObject
ByteArrayToObject works in the same way as
ByteArrayToSerializable but checks if the byte array is a
serialised object and if not will return a String created from the bytes as the
returnType on the transformer. |
class |
ByteArrayToSerializable
ByteArrayToSerializable converts a serialized object to its object
representation |
class |
ExpressionTransformer
This transformer will evaluate one or more expressions on the current message and return the
results as an Array.
|
class |
GetBeanProperty
Looks up a property from a JavaBean using PropertyUtils.getProperty().
|
class |
HexStringToByteArray
Converts a Hex String to a Byte array
|
class |
MapLookup
MapLookup looks up and returns an object from a Map based on a key. |
class |
MessagePropertiesTransformer
A configurable message transformer that allows users to add, overwrite and delete
properties on the current message.
|
class |
MuleMessageToByteArray
TODO
|
class |
ObjectArrayToString
ObjectArrayToString transformer is the opposite of
StringToObjectArray - it simply converts Object[] to a String in which each
element is separated by a configurable delimiter (default is a space). |
class |
ObjectToByteArray
ObjectToByteArray converts serilaizable object to a byte array but
treats java.lang.String differently by converting to bytes using
the String.getBytrs() method. |
class |
ObjectToInputStream
ObjectToInputStream converts serilaizable object to a input stream but
treats java.lang.String differently by converting to bytes using
the String.getBytrs() method. |
class |
ObjectToOutputHandler
ObjectToOutputHandler converts a byte array into a String. |
class |
ObjectToString
ObjectToString transformer is useful for debugging. |
class |
SerializableToByteArray
SerializableToByteArray converts a serializable object or a String
to a byte array. |
class |
StringAppendTransformer |
class |
StringToObjectArray
StringToObjectArray converts a String into an object array. |
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 |
AbstractMessageReceiver
AbstractMessageReceiver provides common methods for all Message
Receivers provided with Mule. |
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.
|
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 |
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 |
EjbMessageReceiver
Will repeatedly call a method on an EJB object.
|
Modifier and Type | Class and Description |
---|---|
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 |
HttpClientMethodResponseToObject
HttpClientMethodResponseToObject transforms a http client response
to a DefaultMuleMessage. |
class |
HttpResponseToString
Converts an Http Response object to String.
|
class |
MuleMessageToHttpResponse
UMOMessageToHttpResponse converts a UMOMEssage into an Http
response. |
class |
ObjectToHttpClientMethodRequest
ObjectToHttpClientMethodRequest transforms a MuleMessage into a
HttpClient HttpMethod that represents an HttpRequest. |
class |
ServletRequestToOutputHandler
Adds support for converting a
HttpServletRequest into an OutputHandler |
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 |
JmsMessageReceiver
Registers a single JmsMessage listener but uses a thread pool to process incoming
messages
|
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 |
AbstractJmsTransformer
AbstractJmsTransformer is an abstract class that should be used for
all transformers where a JMS message will be the transformed or transformee
object. |
class |
JMSMessageToObject
JMSMessageToObject Will convert a javax.jms.Message
or sub-type into an object by extracting the message payload. |
class |
ObjectToJMSMessage
ObjectToJMSMessage will convert any object to a
javax.jms.Message or sub-type into an object. |
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 |
Modifier and Type | Class and Description |
---|---|
class |
QuartzConnector
Creates a connection to a 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 |
RmiMessageReceiver
Will repeatedly call a method on a Remote object.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpRequestToByteArray
Converts an
HttpServletRequest into an array of bytes by extracting the payload of
the request. |
class |
HttpRequestToInputStream
Converts an
HttpServletRequest into an InputStream . |
class |
HttpRequestToParameter |
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 |
WSProxyService
This class is implemented to act as a Proxy for a Web Service.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractWebServiceWrapperComponent |
Modifier and Type | Class and Description |
---|---|
class |
HttpRequestToSoapRequest
A simple transformer for converting an Http GET request into a SOAP request.
|
Modifier and Type | Class and Description |
---|---|
class |
SslConnector
SslConnector provides a connector for SSL connections. |
class |
SslMessageReceiver |
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 |
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 |
TcpMessageReceiver
TcpMessageReceiver acts like a TCP server to receive socket
requests. |
Modifier and Type | Class and Description |
---|---|
class |
UdpConnector
UdpConnector can send and receive Mule events as Datagram packets. |
class |
UdpMessageReceiver
UdpMessageReceiver receives UDP message packets. |
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 |
VMMessageReceiver
VMMessageReceiver is a listener for events from a Mule service which then simply passes
the events on to the target service. |
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.
|
Copyright © 2003–2013 MuleSource, Inc.. All rights reserved.