|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |
ForwardingCatchAllStrategy
acts as a catch and forward router
for any events not caught by the router this strategy is associated with.AbstractCompressionTransformer
is a base class for all
transformers that can compress or uncompress data when they performa message
transformation.AbstractConnector
provides base functionality for all connectors
provided with Mule.AbstractContainerContext
provides base container configuration
functions for handling embedded configurationEncryptionTransformer
will transform an array of bytes or
string into an encrypted array of bytesUrlEndpointBuilder
is the default endpointUri strategy
suitable for most connectorsAbstractEndpointSecurityFilter
provides basic initialisation
for all security filters, namely configuring the SecurityManager for this
instanceAbstractEventAggregator
will aggregate a set of messages into
a single message.AbstractEventAwareTransformer
is a transformer that has a
reference to the current message.AbstractEventResequencer
is used to receive a set of events,
resequence them and forward them on to their destinationAbstractExceptionListener
is a base implementation that custom
Exception Listeners can override.AbstractMessageAdapter
provides a base implementation for
simple message types that maybe don't normally allow for meta information,
such as File or tcp.AbstractMessageDispatcher
provides a default dispatch (client) support for handling threads
lifecycle and validation.AbstractMessageReceiver
provides common methods for all
Message Receivers provided with Mule.AbstractMessageSplitter
is an outbound Message Splitter used
to split the contents of a received message into sup parts that can be
processed by other components.MuleModel
is the default implementation of the UMOModel.AbstractNotificationLoggerAgent
Receives Mule server notifications and logs
them and can optionally route them to an endpointAbstractOutboundRouter
is a base router class that tracks
statistics about message processing through the router.AbstractProxyFactory
provides common behaviour for creating
proxy objectsAbstractRecipientList
is used to dispatch a single event to
multiple recipients over the same transport.AbstractResponseAggregator
provides a base class for implementing
response aggregator routers.AbstractResponseRouter
is a base class for all Response
RoutersAbstractRouterCollection
provides common method
implementations of router collections for in and outbound routers.AbstractServiceEnabledConnector
initialises a connector from a
service descriptor.HtmlTablePrinter
prints event processing stats as a HTML tableAbstractTransformer
Is a base class for all transformers.AdminNotification
is used to invoke actions on a remote mule serverManagementNotificationListener
is an observer interface that objects
can use to receive notifications about the stated of the Mule instance and its
respourcesAllStatistics
todoAlreadyInitialisedException
is thrown when a component or
connector has already been initialised.AndFilter
accepts only if the leftFilter and rightFilter
filter acceptSecurityProviderInfo
.Base64.InputStream
will read data from another InputStream,
given in the constructor, and encode/decode to/from Base64 notation on the fly.Base64.InputStream
in DECODE mode.
Base64.InputStream
in either ENCODE or DECODE mode.
Base64.OutputStream
will write data to another OutputStream,
given in the constructor, and encode/decode to/from Base64 notation on the fly.Base64.OutputStream
in ENCODE mode.
Base64.OutputStream
in either ENCODE or DECODE mode.
Base64Encoder
transforms strings or byte arrays into Base64
encoded stringBase64Encoder
transforms strings or byte arrays into Base64
encoded stringBaseMessage
A default message implementation used for messages
sent over the wire.BatchConstraint
is a filter that counts on every execution and
returns true when the batch size value equals the execution count.BeanUtils
provides functions for altering the way commons BeanUtils
worksBlockingServerEvent
is a marker interface that tells the
server event manager to publish this event in the current thread, thus
blocking the current thread of execution until all listeners have been
processedByteArrayToObject
works in the same way as ByteArrayToSerializable
but checks if th byte array is a serialised object and if not will return a String created from
the bytes is the returnType on the transformer.ByteArrayToSerializable
converts a serialized object to its
object representationByteArrayToString
converts a byte array into a String.CompressionStrategy
implementation class to use, if no
other can be found.
CSVPrinter
prints component stats in CSV formatCallable
is used to provide UMOs with an interface
that supports event calls.ChainedReader
allows Reader objects to be chained together.ChainingRouter
is used to pass a Mule event through multiple
endpoints using the result of the first and the input for the secondCommonsPoolFactory
is a commons-pool pool implementation for
mule.CommonsPoolProxyFactory
is used to create MuleProxies for use
in a proxy pool.CommonsPoolProxyPool
is pool used to store MuleProxy objects.ComponentCatchAllStrategy
is used to catch any events and
forward the events to the component as is.ComponentException
should be thrown when some action on a component
fails, such as starting or stoppingComponentNotification
is fired when an event such as the component
starting occurs.ComponentNotificationListener
is an observer interface that objects
can implement and then register themselves with the Mule manager to be
notified when a Component event occurs.ComponentRoutingException
is thrown due to a routing exception
between the endpoint the event was received on and the component receiving
the eventCompressionException
TODO -document classCompressionHelper
a static class that provides facilities for
compressing and uncompressing byte arraysCompressionStrategy
is a base interface for Different compression strategiesConfigurationBuilder
is a Strategy class used to configure a
UMOManager instance using different configuration mechanisms, such as for
Xml, a script or some other means.ConfigurationException
TODO (document class)ConnectionNotificationListener
is an observer interface that objects
can implement and then register themselves with the Mule manager to be
notified when a Connection event occurs.TransformerConverter
will obtain an endpoint name and convert
it to a UMOConnector
instance by looking up the endpoint in
the MuleManager
.ConnectorException
Is thrown in the context of a UMOConnector, usually some sort of transport
level error where the connection has failed.ConnectorFactory
can be used for generically creating
endpoints from an url.ConnectorFactoryException
is thrown by the endpoint factory if
the endpoint service cannot be found in the META-INF/services directory or if
any part of the endpoint cannot be instanciated.ConnectorServiceDescriptor
describes the necessery information
for creating a connector from a service descriptor.ConnectorServiceException
is thrown if a
ProviderServicedescriptor has a service error set.ConnectorServiceFinder
can be used as a hook into the
connector service creation process to return the correct Service Descriptor
for a given service name.ConnectorServiceNotFoundException
is thorown if no matching
service endpoint descriptor is found for the connector protocol.ContainerException
is an Exception thrown by the component
resolver when it fials to find a componentContainerKeyPair
is a key strategy that binds a container
reference with a container name.ContainerReference
maintains a container reference for the
MuleXmlConfigurationBuilder that gets wired once the configuration documents
have been loadedCoreMessageConstants
contians contants for all Mule core
exception messages and other string.CorrelationAggregator
Uses the CorrelationID and
CorrelationGroupSize properties of the UMOMessage
to
manage message groups.CorrelationEventResequencer
is used to resequence events
according to their dispatch sequence in the correlation group.CorrelationPropertiesExtractor
is a default implementation used
for getting the Correlation information from a message.CouldNotRouteInboundEventException
thrown if the current
component cannot accept the inbound eventCouldNotRouteOutboundMessageException
thrown if Mule fails to
route the current outbound eventCredentialsNotSetException
is thrown when user credentials
cannot be obtained from the current messageCryptoFailureException
is a generic exception thrown by an
CryptoStrategy if encryption or decryption fails.CustomNotification
Custom notifications can be used by components and other
objects such as routers, transformers, agents, etc to communicate a change of
state to each other.CustomNotificationListener
is an observer interface that can be used
to listen for Custom notifications using UMOManager.fireCustomEvent(..)
.container
instead.
DateUtils
contains some useful methods dealing date/time
conversion, formatting etc.EncryptionTransformer
will transform an encrypted array of
bytes or string into an decrypted array of bytesDefaultComponentExceptionStrategy
is the default exception
handler for components.DefaultExceptionStrategy
Provides a default exception handling
strategy.DefaultLifecycleAdapter
provides lifecycle methods for all
Mule managed components.DefaultLifecycleAdapterFactory
TODO (document class)DefaultMessageAdapter
can be used to wrap an arbitary object
where no special 'apapting' is needed.MuleProxy
is a proxy to a UMO.DefaultReplyToHandler
is responsible for processing a message
replyTo header.DispatchException
is thrown when an endpoint dispatcher fails
to send, dispatch or receive a message.Disposable
is a lifecycle interface that gets called at the
dispose lifecycle stage of the implementing component as the component is
being destroyed.DisposeException
is an exception thrownDynamicEntryPoint
is used to detemine the entry point on a
bean after an event has been received for it.DynamicEntryPointResolver
Checks to see if the component implements the Callable lifecycle interface, then the onCall(UMOEventContext) method will be used to receive the event.EchoComponent
will log the message and return the payload back
as the resultEncryptionNotSupportedException
is thrown if an algorithm is
set in the MULE_USER header but it doesn't match the algorithm set on the
security filterEncryptionStrategyNotFoundException
is thrown by the
UMOSecurityManager when an encryption scheme is set in a property or header
that has not been registered witrh the managerEncryptionTransformer
will transform an array of bytes or
string into an encrypted array of bytesEndpointBuilder
determines how a uri is translated to a
MuleEndpointURI Connectors can override the default behaviour to suit their
needsTransformerConverter
will obtain an endpoint name and convert
it to a UMOEndpoint
instance by looking up the proivder from
the MuleManager
.EndpointException
is an abstract exception extended by
endpoint specific exceptions.EndpointNotFoundException
is thrown when an endpoint name or
protocol is specified but a matching endpoint is not registered with the Mule
serverEndpointAbstractEventLoggerAgent
will forward server notifications to
a configurered endpoint uri.EndpointReference
maintains a endpoint reference.EndpointSelector
selects the outgoing endpoint by name based on a
message property ("endpoint" by default).TransformerConverter
will obtain an endpoint name and convert
it to a UMOEndpoint
instance by looking up the proivder from
the MuleManager
.EntryPoint
is a method on a Mule-managed component that is
invoked when an event for the component is received.EnvelopeInterceptor
is an intercepter that will fire before
and after an event is received.EqualsFilter
is a filer for comparing two objects using the
equals() method.EventGroup
is a holder over events grouped by a common group
Id.EventTimerTask
is a task that causes TimeEvent to be fired to
listening objects when a specific number of milliseconds have passed.ExceptionBasedRouter
Will send the current event to the first endpoint
that doesn't throw an exception.ExceptionHelper
provides a number of helper functions that can
be useful for detailing with Mule exceptions.ExceptionMessage
is used by the
DefaultComponentExceptionStrategy for wrapping an exception with a message to
send via an endpointUri.ExceptionPayload
TODOExpirable
implementing classes can be notified when they
expireExpiryMonitor
can monitor objects beased on an expiry time and
can invoke a callback method once the object time has expired.FailedToQueueEventException
is thrown when an event cannot be
put on an internal component queue.FatalException
can be thorwn during initialisation or during
execution to indicate that something fatal has occurred and the MuleManage
must shutdownFileUtils
contains useful methods for dealing with files &
directories.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.FilteringRouter
is a router that accepts events based on a
filter set.ForwardingCatchAllStrategy
acts as a catch and forward router
for any events not caught by the router this strategy is associated with.ForwardingConsumer
is used to forward an incoming event over
another transport without invoking a component.FutureMessageResult
is an UMOMessage result of a remote invocation
on a Mule Server.FutureMessageResult.FutureMessageResult(Callable)
and configure
e.g with FutureMessageResult.setExecutor(Executor)
or
FutureMessageResult.setTransformer(UMOTransformer)
CustomNotificationListener
notificationManager.
CustomNotificationListener
eventManager.
GZipCompressTransformer
is a transformer compressing objects
into byte arraysGZipCompression
a CompressionStrategy implementation using the GZip
library included in the JDK java.util.zip.GZipCompressTransformer
TODOUMOMessageAdapter
for the endpoint for the given
message (data)
UMOMessageAdapter
from the connector for the given
message (data)
UMOStreamMessageAdapter
from the connector for the given
message.
HtmlTablePrinter
prints event processing stats as a HTML tableRoutingException
holds a reference to
the current message and te endpoint being routing to or from when the
error occurred.
IdempotentReceiver
ensures that only unique messages are
received by a component.IdempotentSecureHashReceiver
ensures that only unique
messages are received by a component.IllegalTransactionStateException
TODO (document class)MuleDescriptor
describes all the properties for a Mule UMO.ImmutableMuleEndpoint
describes a Provider in the Mule Server.InboundMessageRouter
is a collection of routers that will be
invoked when an event is received It is responsible for manageing a
collection of routers and also executing the routing logic.InboundPassThroughRouter
allows intbound routing over all
registered endpoints without any filtering.Initialisable
is a lifecycle interface that gets called at the
initialise lifecycle stage of the implementing component.InitialisationCallback
is used to provide customised
initialiation for more complex components.InitialisationException
is thrown by the initialise method
defined in the org.mule.umo.lifecycle.Initialisable
interface.InterceptorsInvoker
is used trigger an interceptor chain.Invocation
represents a link in an interceptor chain.inboundRouter
instead.
inboundRouter
instead.
EntryPoint
is avoid method or not
JndiContainerContext
is a container implementaiton that
exposes a jndi context.Lifecycle
adds lifecycle methods start
,
stop
and dispose
.LifecycleException
TODOLifecycleInterceptor
is a UMOInterceptor interface with two
additional lifecycle methods provided by Initialisable
and
Disposable- Log4jNotificationLoggerAgent - class org.mule.impl.internal.admin.Log4jNotificationLoggerAgent.
AbstractNotificationLoggerAgent
Receives Mule server notifications and logs
them and can optionally route them to an endpoint- Log4jNotificationLoggerAgent() -
Constructor for class org.mule.impl.internal.admin.Log4jNotificationLoggerAgent
-
- LogComponent - class org.mule.components.simple.LogComponent.
LogComponent
Simply logs the content (or content length if it
is a large message)- LogComponent() -
Constructor for class org.mule.components.simple.LogComponent
-
- LogService - interface org.mule.components.simple.LogService.
-
- LoggingCatchAllStrategy - class org.mule.routing.LoggingCatchAllStrategy.
LoggingCatchAllStrategy
is a simple strategy that only logs
any events not caught by the router associated with this strategy.- LoggingCatchAllStrategy() -
Constructor for class org.mule.routing.LoggingCatchAllStrategy
-
- LoggingInterceptor - class org.mule.interceptors.LoggingInterceptor.
LoggingInterceptor
is a simple interceptor that logs a message
before and after the event processing.- LoggingInterceptor() -
Constructor for class org.mule.interceptors.LoggingInterceptor
-
- list(Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- list(Attributes.Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- list(String) -
Method in class org.mule.impl.jndi.SimpleContext
-
- list -
Variable in class org.mule.util.queue.QueueInfo
-
- listBindings(Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- listBindings(String) -
Method in class org.mule.impl.jndi.SimpleContext
-
- listCryptoImplementations(String) -
Static method in class org.mule.util.DebugUtils
-
- listSecurityServiceTypes() -
Static method in class org.mule.util.DebugUtils
-
- load(UMOEvent) -
Method in class org.mule.routing.inbound.IdempotentReceiver
-
- load(String, Object) -
Method in class org.mule.util.queue.CachingPersistenceStrategy
-
- load(String, Object) -
Method in class org.mule.util.queue.FilePersistenceStrategy
-
- load(String, Object) -
Method in class org.mule.util.queue.MemoryPersistenceStrategy
-
- load(String, Object) -
Method in interface org.mule.util.queue.QueuePersistenceStrategy
- Loads an object specified by the given id.
- loadClass(String, Class) -
Static method in class org.mule.util.ClassUtils
- Load a class with a given name.
- loadProperties(String, Class) -
Static method in class org.mule.util.PropertiesUtils
- Read in the properties from a properties file.
- loadSystemProperties -
Variable in class org.mule.impl.container.PropertiesContainerContext
-
- localContext -
Variable in class org.mule.util.xa.DefaultXASession
-
- localXid -
Variable in class org.mule.util.xa.DefaultXASession
-
- log(String) -
Method in class org.mule.components.simple.LogComponent
-
- log(String) -
Method in interface org.mule.components.simple.LogService
-
- logBoilerPlate(List) -
Method in class org.mule.util.MuleLogger
-
- logBoilerPlate(String[]) -
Method in class org.mule.util.MuleLogger
-
- logEvent(UMOServerNotification) -
Method in class org.mule.impl.internal.admin.AbstractNotificationLoggerAgent
-
- logEvent(UMOServerNotification) -
Method in class org.mule.impl.internal.admin.EndpointNotificationLoggerAgent
-
- logEvent(UMOServerNotification) -
Method in class org.mule.impl.internal.admin.Log4jNotificationLoggerAgent
-
- logException(Throwable) -
Method in class org.mule.impl.AbstractExceptionListener
- Used to log the error passed into this Exception Listener
- logFatal(UMOMessage, Throwable) -
Method in class org.mule.impl.AbstractExceptionListener
- Logs a fatal error message to the logging system.
- logFatal(UMOMessage, Throwable) -
Method in class org.mule.impl.DefaultComponentExceptionStrategy
-
- logSummary() -
Method in class org.mule.management.stats.AllStatistics
-
- logSummary(PrintWriter) -
Method in class org.mule.management.stats.AllStatistics
-
- logSummary() -
Method in class org.mule.management.stats.ComponentStatistics
- log in info level the main statistics
- logSummary(PrintWriter) -
Method in class org.mule.management.stats.ComponentStatistics
-
- logSummary() -
Method in class org.mule.management.stats.RouterStatistics
-
- logSummary(PrintWriter) -
Method in class org.mule.management.stats.RouterStatistics
-
- logSummary() -
Method in interface org.mule.management.stats.Statistics
-
- logger -
Variable in class org.mule.components.builder.AbstractMessageBuilder
- logger used by this class
- logger -
Variable in class org.mule.components.rest.RestServiceWrapper
- logger used by this class
- logger -
Static variable in class org.mule.config.ExceptionHelper
- logger used by this class
- logger -
Variable in class org.mule.config.MuleConfiguration
- logger used by this class
- logger -
Static variable in class org.mule.config.MuleDtdResolver
- logger used by this class
- logger -
Static variable in class org.mule.config.builders.ContainerReference
- logger used by this class
- logger -
Static variable in class org.mule.config.builders.EndpointReference
- logger used by this class
- logger -
Static variable in class org.mule.config.builders.TransformerReference
- logger used by this class
- logger -
Static variable in class org.mule.config.i18n.Messages
- logger used by this class
- logger -
Static variable in class org.mule.config.pool.CommonsPoolProxyPool
- logger used by this class
- logger -
Variable in class org.mule.impl.AbstractExceptionListener
- logger used by this class
- logger -
Static variable in class org.mule.impl.DefaultLifecycleAdapter
- logger used by this class
- logger -
Static variable in class org.mule.impl.ImmutableMuleEndpoint
- logger used by this class
- logger -
Variable in class org.mule.impl.MuleEvent
- logger used by this class
- logger -
Static variable in class org.mule.impl.MuleEventContext
- logger used by this class
- logger -
Variable in class org.mule.impl.MuleSessionHandler
- logger used by this class
- logger -
Static variable in class org.mule.impl.MuleTransactionConfig
- logger used by this class
- logger -
Variable in class org.mule.impl.container.AbstractContainerContext
- logger used by this class
- logger -
Static variable in class org.mule.impl.container.MultiContainerContext
- logger used by this class
- logger -
Static variable in class org.mule.impl.endpoint.MuleEndpointURI
- logger used by this class
- logger -
Variable in class org.mule.impl.internal.admin.AbstractNotificationLoggerAgent
- The logger used for this class
- logger -
Static variable in class org.mule.impl.internal.admin.MuleAdminAgent
- logger used by this class
- logger -
Static variable in class org.mule.impl.internal.admin.MuleManagerComponent
- logger used by this class
- logger -
Static variable in class org.mule.impl.internal.notifications.MessageNotification
- logger used by this class
- logger -
Static variable in class org.mule.impl.internal.notifications.ServerNotificationManager
- logger used by this class
- logger -
Variable in class org.mule.impl.model.AbstractComponent
- logger used by this class
- logger -
Variable in class org.mule.impl.model.AbstractModel
- logger used by this class
- logger -
Variable in class org.mule.impl.security.AbstractEndpointSecurityFilter
- logger used by this class
- logger -
Variable in class org.mule.impl.security.AbstractJCEEncryptionStrategy
- logger used by this class
- logger -
Static variable in class org.mule.impl.security.MuleSecurityManager
- logger used by this class
- logger -
Static variable in class org.mule.impl.work.MuleWorkManager
- logger used by this class
- logger -
Static variable in class org.mule.impl.work.WorkerContext
- logger used by this class
- logger -
Static variable in class org.mule.model.DynamicEntryPoint
- logger used by this class
- logger -
Static variable in class org.mule.model.EntryPoint
- logger used by this class
- logger -
Variable in class org.mule.providers.AbstractConnectionStrategy
- logger used by this class
- logger -
Variable in class org.mule.providers.AbstractConnector
- logger used by this class
- logger -
Variable in class org.mule.providers.AbstractMessageAdapter
- logger used by this class
- logger -
Variable in class org.mule.providers.AbstractMessageDispatcher
- logger used by this class
- logger -
Variable in class org.mule.providers.AbstractMessageReceiver
- logger used by this class
- logger -
Static variable in class org.mule.providers.DefaultReplyToHandler
- logger used by this class
- logger -
Static variable in class org.mule.providers.service.ConnectorFactory
- logger used by this class
- logger -
Static variable in class org.mule.providers.service.ConnectorServiceDescriptor
- logger used by this class
- logger -
Variable in class org.mule.routing.AbstractCatchAllStrategy
- logger used by this class
- logger -
Static variable in class org.mule.routing.inbound.AbstractEventResequencer
- logger used by this class
- logger -
Static variable in class org.mule.routing.inbound.InboundMessageRouter
- logger used by this class
- logger -
Variable in class org.mule.routing.inbound.SelectiveConsumer
- logger used by this class
- logger -
Variable in class org.mule.routing.outbound.AbstractOutboundRouter
- logger used by this class
- logger -
Static variable in class org.mule.routing.outbound.AbstractRecipientList
- logger used by this class
- logger -
Static variable in class org.mule.routing.outbound.ChainingRouter
- logger used by this class
- logger -
Static variable in class org.mule.routing.outbound.OutboundMessageRouter
- logger used by this class
- logger -
Variable in class org.mule.routing.response.AbstractResponseAggregator
- logger used by this class
- logger -
Static variable in class org.mule.routing.response.ResponseMessageRouter
- logger used by this class
- logger -
Variable in class org.mule.transaction.AbstractTransaction
-
- logger -
Static variable in class org.mule.transaction.TransactionCoordination
- logger used by this class
- logger -
Variable in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- logger -
Variable in class org.mule.transformers.AbstractTransformer
- logger used by this class
- logger -
Variable in class org.mule.umo.manager.DefaultWorkListener
- logger used by this class
- logger -
Variable in class org.mule.umo.security.provider.AutoDiscoverySecurityProviderFactory
- Logger used by this class.
- logger -
Static variable in class org.mule.util.SystemUtils
-
- logger -
Static variable in class org.mule.util.TemplateParser
- logger used by this class
- logger -
Static variable in class org.mule.util.monitor.ExpiryMonitor
- logger used by this class
- logger -
Variable in class org.mule.util.xa.AbstractResourceManager
-
- logger -
Variable in class org.mule.util.xa.DefaultXASession
- logger used by this class
- lookup(Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- lookup(String) -
Method in class org.mule.impl.jndi.SimpleContext
-
- lookupAgent(String) -
Method in class org.mule.MuleManager
-
- lookupAgent(String) -
Method in interface org.mule.umo.manager.UMOManager
- Will find a registered agent using its name, which is unique for all registered agents
- lookupComponent() -
Method in class org.mule.impl.model.AbstractComponent
- Provides a consistent mechanism for custom models to create components.
- lookupConnector(String) -
Method in class org.mule.MuleManager
-
- lookupConnector(String) -
Method in interface org.mule.umo.manager.UMOManager
-
- lookupEndpoint(String) -
Method in class org.mule.MuleManager
- Getter for a global endpoint. Any endpoints returned from this method can
be modified, as they are clones of the registered endpoints.
- lookupEndpoint(String) -
Method in class org.mule.routing.outbound.EndpointSelector
-
- lookupEndpoint(String) -
Method in interface org.mule.umo.manager.UMOManager
- Getter for a global endpoint.
- lookupEndpointIdentifier(String, String) -
Method in class org.mule.MuleManager
-
- lookupEndpointIdentifier(String, String) -
Method in interface org.mule.umo.manager.UMOManager
-
- lookupInterceptorStack(String) -
Method in class org.mule.MuleManager
- Retrieves a configured interceptor stack.
- lookupInterceptorStack(String) -
Method in interface org.mule.umo.manager.UMOManager
- Retrieves a configured interceptor stack.
- lookupLink(Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- lookupLink(Attributes.Name) -
Method in class org.mule.impl.jndi.SimpleContext
-
- lookupLink(String) -
Method in class org.mule.impl.jndi.SimpleContext
-
- lookupTransformer(String) -
Method in class org.mule.MuleManager
- Getter method for a Transformer.
- lookupTransformer(String) -
Method in interface org.mule.umo.manager.UMOManager
- Getter method for a Transformer.
MalformedEndpointException
is thrown by the MuleEndpointURI
class if it fails to parse a UrlManagementNotification
is fired when monitored resources such as
internal queues reach capacityManagementNotificationListener
is an observer interface that objects
can use to receive notifications about the stated of the Mule instance and its
resourcesManagerException
is thrown when an exception occurs with
Manager objectsManagerNotification
is fired when an event such as the manager
starting occurs.ManagerNotificationListener
is an observer interface that objects can
implement and then register themselves with the Mule manager to be notified
when a Manager event occurs.ManualConstraint
always returns false, meaning that the transaction
should be committed manually.MapLookup
looks up and returns an object from a Map based on a key.Message
constructs aMessageNormalizerInterceptor
can be used as a simple pre/post
message normalizer for a given component.MessageNotificationListener
is an observer interface that objects
can use to receive notifications about messages being sent and received from a Mule ServerMessagePropertyFilter
can be used to filter against properties
on an event.MessageTypeNotSupportedException
is thrown when a message payload
is set on a Message implementation of MessageAdapter which is not of supported
type for that message or adapter.Messages
provides facilities for constructing
Message
objects and access to core message constants.MessagingException
is a general message exception thrown when
errors specific to Message processing occur.ModelNotification
is fired when an event such as the model starting
occurs.ModelNotificationListener
is an observer interface that objects can
implement and then register themselves with the Mule manager to be notified
when a Model event occurs.MuleAdminAgent
manages the server endpoint that receives Admin
and remote client requestsMuleAuthentication
TODOMuleConfiguration
holds the runtime configuration specific to
the MuleManager
.MuleContainerContext
is a default resolver that doesn't support
external reference resolution.MuleCredentials
can be used to read and set Mule user
information that can be stored in a message headerMuleDescriptor
describes all the properties for a Mule UMO.MuleDtdResolver
attempts to locate the mule-configuration.dtd
on the classpath, regardless of the DOCTYPE declaration.MuleEncryptionEndpointSecurityFilter
provides password-based
encriptionMuleEndpoint
describes a Provider in the Mule Server.MuleEndpointURI
is used to determine how a message is sent of received.MuleEvent
represents any data event occuring in the Mule
environment.MuleEventContext
is the context object for the current
request.MuleException
Is the base exception type for the Mule
application any other exceptions thrown by Mule code will be based on this
exception.MuleHeaderCredentialsAccessor
obtains and sets the user
credentials as Mule property headersLog
wrapper that supports boilerplate logging for high impact messagesMuleManager
maintains and provides services for a Mule
instance.MuleManagerComponent
is a MuleManager interal server component
responsible for receiving remote requests and dispatching them locally.MuleMessage
is a wrapper that contains a payload and
properties associated with the payload.MuleObjectHelper
is a helper class to assist in finding mule server
objects, such as endpoint and transformersMuleProperties
is a set of constants pertaining to Mule system
properties.MuleProxy
is a proxy to a UMO.MuleRuntimeException
Is the base runtime exception type for
the Mule Server any other runtimes exceptions thrown by Mule code will use or
be based on this exception.MuleSecurityManager
is a default implementation security
manager for a Mule instanceMuleServer
is a simple application that represents a local
Mule Server daemon.MuleSession
manages the interaction and distribution of events
for Mule UMOs.MuleTransactionConfig
defines transaction configuration
for a transactional endpoint.MuleWorkManager
is a Jca Work manager implementation used to
manage thread allocation for Mule components and connectors
This code has been adapted from the Geronimo implementation, and the
different pool executors have be used directly from GeronimoMultiContainerContext
is a container that hosts other
containers from which components are queried.Multicaster
is a utility that can call a given method on a
collection of objects that implement one or more common interfaces.MulticastingRouter
will broadcast the current message to every
endpoint registed with the router.NoActionTransformer
doesn't do any transformation on the source
object and returns the source as the result.NoReceiverForEndpointException
is thrown when an enpoint is
specified for a receiver but no such receiver exists.NoSatisfiableMethodsException
is thrown by EntryPointResolvers
when the component passed has no methods that meet the criteria of the
configured EntryPointResolver.NotFilter
accepts if the filter does not acceptNullPayload
represents a null event payloadNumberUtils
contains useful methods for manipulating numbers.ObjectFactory
is a generic Factory interface.ObjectNotFoundException
is thrown when a reference to a
component in a configured container is not foundObjectPool
is a simple pooling interface for objectsObjectToByteArray
converts serilaizable object to a byte array but
treats java.lang.String
differently by converting to bytes using the
String.getBytrs()
method.ObjectToString
transformer is useful for debugging.MuleProxy
is a proxy to a UMO.OrFilter
accepts if the leftFilter or rightFilter filter
acceptStreamMessageAdapter
wraps an java.io.OutputStream and allows meta information
to be associated with the streamOutboundMessageRouter
is a container of routers.InboundPassThroughRouter
allows outbound routing over a single
endpoint without any filtering.outboundRouter
instead.
outboundRouter
instead.
PassThroughComponent
will simply return the payload back
as the resultPayloadTypeFilter
filters based on the type of the object
received.PollingMessageReceiver
implements a polling message receiver.PoolingProfile
is a configuration object used to define the
object pooling parameters for the component it is associated with.PropertiesHelper
is a utility class for manipulating and filtering
property Maps.PropertyExtractor
extracts a property from the message in a
generic way.PropertyFactory
is used to create objects from the property
file.TransformerConverter
will obtain an endpoint name and convert
it to a UMOConnector
instance by looking up the endpoint in
the MuleManager
.Queue
TODOQueuePersistenceStrategy
defines the The api to
a persistent queue store.QueueProfile
determines how an internal queue for a component
will behaveQuickConfigurationBuilder
is a configuration helper that can
be used by clients, configuration scripts or test cases to quickly configure
a managerReaderResource
is a reader with a description associated with
it.ReceiveException
is specifically thrown by the Provider
receive method if something fails in the underlying transportRecoverableException
can be thrown during initialisation to
indicate that the error occurred is not fatal and a reactive action can be
performed to try and remedy the error.RegExFilter
is used to match a rgular expression against a
string argument.ReplyToHandler
is used to handle routing where a replyTo
endpointUri is set on the messageRequestContext
is a thread context where components can get
the current event or set response properties that will be sent on the
outgoing message.ResourceNameEndpointBuilder
extracts a resource name from a
uri endpointUriResponseCorrelationAggregator
Correlates one or more events on a
response flow using the Correlation Id to group events.ResponseMessageRouter
is a router that can be used to control
how the response in a request/response message flow is created.ResponseOutputStream
is an output stream associated with the
currently received event.ResponseTimeoutException
is thrown when a response is not
received in a given timeout in the Response Router.RmiContainerContext
is a container implementaiton that
allows RMi objects to be referenced either as components or properties on componentsRoutePathNotFoundException
is thrown if a routing path for an
event cannot be found.RouterStatistics
todoRoutingException
is a base class for al routing exceptions.Base64.InputStream.read()
repeatedly until the end of stream is reached or len
bytes are read.
UMODescriptor
with the
MuleManager
.
UMOConnector
with the MuleManager
.
UMOConnector
with the MuleManager
.
MuleManager
.
MuleManager
.
UMOMessageReceiver
associated with this
endpoint and registers it with the connector
MuleManager
.
MuleManager
.
responseRouter
instead.
Runnable
is used to
create a thread, starting the thread causes the object's run
method to be called in that separately executing thread.
SecurityException
is a generic security exceptionSecurityNotification
is fired when a request for authorisation
occurs.ManagerNotificationListener
is an observer interface that objects can
implement to receive notifications about secure access requests.SecurityProviderNotFoundException
is thrown by the
UMOSecurityManager when an authentication request is made but no suitable
security provider can be found to process the authenticationSelectiveConsumer
is an inbound router used to filter out
unwanted events.SerializableToByteArray
converts a serializable object or a
String to a byte array.ServerNotificationManager
manages all server listeners for a Mule
InstanceSessionException
is thrown when errors occur in the
MuleSession or Seession ManagerSimplePrinter
Default stats printerSocketEndpointBuilder
builds an endpointUri based on host and
port onlyStartable
TODO (document class)StaticRecipientList
is used to dispatch a single event to
multiple recipients over the same transport.Statistics
todoStoppable
TODO (document class)StringMessageHelper
contains some useful methods for formatting
message strings for logging or exceptions.StringToByteArray
converts a string into a byte arrayStringUtils
contains useful methods for manipulating Strings.MuleManager
.
MuleManager
.
MuleManager
.
MuleManager
.
MuleManager
which stops all sessions and
connectors
Transformer
implementation class to use, if no other can be found.
TemplateParser
is a simple string parser that will substitute
tokens in a string with values supplied in a Map.ThreadingProfile
is used to configure a thread pool.TimeEvent
TODO is an event that occurs at a specified number
of milliseconds.TimeEventListener
provides a method to pass timer events to
implementing objects.TimerInterceptor
simply times and displays the time taken to
process an event.TooManySatisfiableMethodsException
is thrown by
EntryPointResolvers when the component passed has more than one methods that
meet the criteria of the configured EntryPointResolver.TransactionException
is thrown when an exception occurs while
trying to create, start commit or rollback an exceptionTransactionFactoryConverter
TODOTransactionInProgressException
is thrown if a new transaction
is started when there is one already in progressTransactionNotInProgressException
TODO (document class)TransformerConverter
will obtain a transformer name and
convert it to a transformer instance by looking up the transformer from the
MuleManager
.TransformerException
is a simple exception that is thrown by
transformers.TransformerReference
maintains a transformer reference.Class
as
element type.
Base64Encoder
transforms strings or byte arrays into Base64
encoded stringBase64Encoder
transforms strings or byte arrays into UU
encoded stringUMOAgent
is a server plugin that can be initialised, started and
destroyed along with the UMOManager itself.UMOAuthentication
represents an authentication request and
contains authentication information if the request was successfulUMOComponent
is the interal repesentation of a Mule Managed
component.UMOComponentFactory
is used to create UMOComponent instancesUMOConnector
is the mechanism used to connect to external
systems and protocols in order to send and receive data.UMOContainerContext
defines the contract between Mule and an
underlying container such as String or Pico.UMOCredentials
holds credentials information for a user.UMOCredentialsAccessor
is a template for obtaining user
credentials from the current message and writing the user credentials to an
outbound messageUMODescriptor
describes all the properties for a Mule UMO.UMODescriptorAware
is an injector interface that will supply a
UMODescriptor to the object.UMOEncryptionStrategy
can be used to provide different types
of Encryption strategy objects.UMOEndpoint
describes a Provider in the Mule Server.UMOEndpointSecurityFilter
is a base filter for secure
filtering of inbound and outbout event flowUMOEndpointURI
is used to determine how a message is sent or
received.UMOEntryPoint
defines the current entry method on a componentUMOEntryPointResolver
resolves a method to call on the given
UMODescriptor when an event is received for the componentUMOEvent
represents any data event occuring in the Mule
environment.UMOEventContext
is the context object for the current request.UMOEventListener
is a marker interface that is implemented by
ojects wishing to receive UMO events in managed environments, succh as an ejb
container.UMOException
is the base exception type for the Mule server
any other exceptions thrown by Mule code will be based on this exceptionUMOExceptionPayload
is a message payload that contains
exception information that occurred during message processingUMOFilter
interface allows UMOMessage filtering.UMODescriptor
describes all the properties for a Mule UMO.UMOImmutableEndpoint
describes a Message endpoint where data
is sent or received.InboundRouterCollection
manages a collection of inbound
routersUMOInboundRouter
defines an interface for an inbound Message
router.UMOInterceptor
is based on a similar concept of servlet
filters and works much the same way.UMOLifecycleAdapter
TODO (document class)UMOLifecycleAdapterFactory
TODO (document class)UMOManager
maintains and provides services for a UMO server
instance.UMOMessage
represents a message payload.UMOMessageAdapter
provides a common abstraction of different
message implementations provided by different underlying technologiesUMOMessageDispatcher
is the interface responsible for distpatching events to a particular transport.UMOMessageDispatcherFactory
is a factory interface for creating a Message Dispatcher
for the underlying transportUMOMessageReceiver
is used to receive data from an external
system.UMOModel
encapsulates and manages the runtime behaviour of
a Mule Server instance.UMOOutboundMessageRouter
TODOUMOOutboundRouter
is used to control outbound routing
behaviour for an event.UMOPoolFactory
is a factory interface for created a component pool instanceUMOResponseMessageRouter
is a router that can be used to
control how the response in a request/response message flow is created.UMOResponseRouter
is a router that handles response flow
Response Agrregators are used to collect responses that are usually sent to replyTo endpoints set
on outbound routers.UMORouter
A placeholed interfae for all routersUMORouterCatchAllStrategy
TODOUMORouterCollection
defines the interface for a MessageRouter that
manages more than one router.UMOSecurityContext
holds security information and is
associated with the UMOSession.UMOSecurityContextFactory
is responsible for creating a
UMOSecurityContext instance.UMOSecurityManager
is responsible for managing a one or more
security providers.UMOSecurityProvider
is a target security provider thsat
actually does the work of authenticating credentials and populating the
UMOAuthentication object.UMOServerNotification
is an event triggered by something happening in
the Server itself such as the server starting or a component being registeredUMOServerNotificationListener
is an observer interface that ojects
can implement and register themselves with the Mule Server to receive
notifications when the sevrver, model and components stop, start, initilise,
etc.UMOSession
is the context in which a request is executed.UMOSimpleTransformer
manages the transformation and or
translation of one type of data to the other.UMOTransactionConfig
defines transaction configuration for a
transactional endpoint.UMOTransactionFactory
creates a transaction.TranactionManagerFactory
is a factory class for creating a
transaction manager for the MuleServer.UMOTransformer
extends a UMOSimpleTransformer with the
provision of a Transformer component, which simply keeps a copy of the 'live'
transfromed data, so that any further transformations will use this cached
data.UMOWorkManager
Extends the stanard WorkManager to add lifecycle methodsBase64Encoder
transforms strings or byte arrays into Base64
encoded stringBase64Encoder
transforms strings or byte arrays into UU
encoded stringUUID
Generates a UUID using the JUG libraryUnauthorisedException
is thrown if authentication failsUniqueIdNotSupportedException
is thrown by
UMOMessageAdapter.getUniqueId() if the underlying message does not support or
have a unique identifier.UnknownAuthenticationTypeException
is thrown if a security
context request is make with an unrecognised UMOAuthentication type.UnsupportedAuthenticationSchemeException
is thrown when a
authentication scheme is being used on the message that the Security filter
does not understandUrlEndpointBuilder
is the default endpointUri strategy
suitable for most connectorsUserInfoEndpointBuilder
builds an endpoint with the userinfo
and host details.UMOConnector
with the
MuleManager
.
UMOConnector
with the
MuleManager
.
MuleManager
.
MuleManager
.
MuleManager
.
MuleManager
.
WildcardFilter
is used to match wildcard string.WorkExecutor
TODOWorkerContext
TODOWriterMessageAdapter
wraps a java.io.StringWriter and allows meta information
to be associated with the writerBase64.OutputStream.write(int)
repeatedly until len bytes are written.
XaTransaction
represents an XA transaction in Mule.XaTransactionFactory
Is used to create/retreive a Transaction
from a transaction manager configured on the MuleManager.
|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |