|
|||||||||||
| 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.AbstractConnectorTestCase tests common behaviour of all endpoints
and provides 'reminder' methods for implementation specific interface methodsAbstractContainerContext 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 instanceComponentMethodMapping is used to supply a component class and
the correct method to be resovled on the component.AbstractEventAggregator 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 destinationAbstractEventTransformer adds support for adding method details to
the result message.AbstractExceptionListener TODO (document class)AbstractExceptionListener is a base implementation that custom
Exception Listeners can override.AbstractFruit TODO (document class)AbstractJmsTransformer is an abstract class that should be used for
all transformers where a JMS message will be the transformed or transformee
object.AbstractMailFilter is a base class for all javax.mail.Message
filters.AbstractMessageAdapter provides a base implementation for simple
message types that maybe don't normally allow for meta information, such as a 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.AbstractMuleTestCase is a base class for Mule testcases.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.AbstractPoolTestCase TODO (document class)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.AbstractScriptComponent is a component that can execute scripts as
components in Mule.AbstractServiceEnabledConnector initialises a connector from a
service descriptor.HtmlTablePrinter prints event processing stats as a HTML tableAbstractTransformer Is a base class for all transformers.AbstractXStreamTransformer is a base class for all XStream based
transformers.AbstractXmlTransformer offers some XSLT transform on a DOM (or
other XML-ish) object.AbstractXmppFilter is a filter adapter so that Smack Filters can be
configured as Mule filters.AcegiAuthenticationAdapter TODOAcegiProviderAdapter is a wrapper for an Acegi Security provider to
use with the UMOSecurityManagerAcegiSecurityContext is a UMOSecurityContext wrapper used to
interface with an Acegi SecurityContextAcegiSecurityContextFactory creates an AcegiSecurityContext for an
UMOAuthentication objectAddress is a Persons addressAdminNotification 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
accept.ApplicationEventException TODOLoanBroker is the Service that starts the loan request process.AsynchronousEventListener will spawn a thread for each Event
received.SecurityProviderInfo.UMOManagerFactoryBean is a MuleManager factory bean that is used to
configure the MuleManager from a spring context.AxisConnector is used to maintain one or more Services for Axis
server instance.AxisInitialisable can be implemented by a Mule component that will
be used as an Axis service to customise the Axis Service objectAxisInitialisationCallback is invoked when an Axis component is
created from its descriptor.AxisMessageAdapter wraps a soap message.AxisMessageDispatcher is used to make soap requests via the Axis
soap client.AxisMessageDispatcherFactory creates an AxisMessageDispatcher, used
for making soap calls using the Axis stack.AxisMessageReceiver is used to register a component as a service
with a Axis server.AxisServiceComponent is a Mule component implementation of the Axis
servlet.ServiceProxy is a proxy that wraps a soap endpointUri to look like
a Web service.BananaFactory is a test factory that creates BananasBank is a representation of a bank from which to obtain loan
quotes.Bank is a representation of a bank form which to obtain loan
quotes.BankQuoteRequest represents customer a request for a loan broker
through a loan brokerBankQuotesAggregator receives a number of quotes and selectes the
lowestBankQuotesAggregator receives a number of quotes and selectes the
lowestBankQuotesAggregator receives a number of quotes and selects the
lowest.BankService is a representation of a bank form which to obtain loan
quotes.BankService is a representation of a bank form which to obtain loan
quotes.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 processedBusinessErrorManager TODO (document class)BusinessException TODO (document class)BusinessHandler TODO (document class)ByteArrayToObject 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 second.ChatString TODO (document class)NameStringToChatString is a dummy transform used in the hello world
application to transform the ChatString object into a stringChitChatter TODO (document class)CommonsPoolFactory 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
eventComponentService exposes service information about a Mule Managed
componentComponentServiceMBean defines the management interface for a mule
managed componentComponentStats TODOComponentStatsMBean TODOCompressionException 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.ConnectorConverter TODOConnectorException 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 loaded.CoreMessageConstants 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 messageCreditAgency defines the interface for the credit agency serviceCreditAgencyBean obtains a credit historey record for a customer.CreditAgencyHome the home inteface for the credit agency serviceCreditAgencyService the service that provides a credit score for a
customer.CreditProfile is a dummy finance profile for a customerCreditProfile is a dummy finance profile for a customerCryptoFailureException 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(..).Customer the loan broker customerCustomer the loan broker customerCustomerQuoteRequest is the request sent by the the LoanBrokercontainer instead.
DQConnector is a delegate provider that encapsulates an AS400
DataQueue provider.DQEndpointBuilder constructs an endpoint used by AS400 data queuesDQMessage is an encapsulation of a DataQueue message.DQMessageAdapter provides a wrapper for a DataQueue Message.DQMessageDispatcher TODO documentDQMessageToXml Will convert a DQMessage to an xml string by
extracting the message payload.DateService defines a Date serviceDateUtils 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.DefaultConnectionManager TODODefaultCreditAgencyService the service that provides a credit score
for a customerDefaultExceptionStrategy Provides a default exception handling
strategy.DefaultHandler TODO (document class)DefaultLenderService is responsible for contacting the relevant
banks depending on the amount of the loanDefaultLifecycleAdapter 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.MuleConnection TODODefaultMuleConnectionFactory an implementation of the
MuleconnectionFactory interface used by clients of this ResourceAdapter to obtain
a connection to Mule resources.MuleProxy is a proxy to a UMO.DefaultRedeliveryHandler TODODefaultReplyToHandler is responsible for processing a message
replyTo header.DelegateWorkManager TODODispatchException 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 thrownDomDocumentToXml Transform a org.w3c.dom.Document to XML StringDynamicEntryPoint 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.org.apache.hivemind.events.RegistryShutdownListener.
FileToByteArray to get a
byte[] from the file beeing parsed and then transform it to a
String with the correct encoding.
EchoComponent will log the message and return the payload back as
the resultEjbContainerContext is a container implementaiton that allows EJB
Session beans to be referenced as Mule managed UMOsEjbMessageDispatcherFactory creates a dispatcher for marshalling
requests to an EJB Session beanEmailMessageToString extracts a java mail Message contents and
returns a string.EncryptionNotSupportedException 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 needsEndpointConverter TODOEndpointException 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 based on a
message property ("endpoint" by default).EndpointURIConverter TODOEntryPoint 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 filter for comparing two objects using the
equals() method.ErrorManager TODO (document class)ErrorMessage TODO (document class)EventCallback TODO (document class)EventGroup is a holder over events grouped by a common group Id.EventObjectTransformer converts a
java.util.EventObject into a MuleMessage.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.ExceptionBean TODO -document classExceptionHandler TODO (document class)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 TODO (document class)FatalException can be thorwn during initialisation or during
execution to indicate that something fatal has occurred and the MuleManage must
shutdownFatalBehaviour TODO (document class)FileConnector is used for setting up listeners on a directory and
for writing files to a directory.FileContentsMessageAdapter provides a wrapper for file data.FileEndpointBuilder File uris need some special processing because
the uri path can be any length, and the default resolver relies on a particular
path format.FileMessageAdapter provides a wrapper for a file reference.FileMessageDispatcher is used to read/write files to the filesystemFileMessageDispatcherFactory creaes a dispatcher responsible for
writing files to diskFileMessageReceiver is a polling listener that reads files from a
directory.FileToByteArray reads the contents of a file as a byte array.FileToString reads file contents into a string.FileUtils contains useful methods for dealing with files &
directories.FilenameParser is a simple expression parser interface for
processing filenamesFilenameWildcardFilter filters incoming files from a directory,
based on file patterns.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.FilteringXmlMessageSplitter will split a DOM4J document into nodes
based on the "splitExpression" property.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.FunctionalTestComponent is a component that can be used by
functional tests.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 is a CompressionStrategy implementation using the
GZip library included in the JDK java.util.zip.GZipCompressTransformer TODOGlueConnector instanciates a Glue soap server and allows beans to
be dynamically exposed via web services simply by registering with the connector.GlueInitialisable can be implemented by a Mule component that will
be used as an Glue Soap service to customise the Glue Service objectGlueInitialisationCallback is invoked when an Glue service
component is created from its descriptor.GlueMessageAdapter wraps a Glue soap requestGlueMessageDispatcher will make web services calls using the Glue
invoking mechanism.GlueMessageDispatcherFactory Creates a Soap Message dispatcher that
uses glueGlueMessageReceiver is used to receive Glue bounded services for
Mule components.GlueServiceInitialisable registers your service component to be
notified when it is being registered as a Glue soap service.ServiceProxy is a proxy that wraps a soap endpointUri to look like
a Web service.Greeter TODO (document class)UMOMessageAdapter for the endpoint for the given message
(data)
UMOMessageAdapter from the connector for the given
message (data)
HttpResponse.getStatusCode() instead
UMOStreamMessageAdapter from the connector for the given
message.
getExpectedValue().
HiveMindContext is a HiveMind Context that can expose HiveMind
managed services for use in the Mule framework.HtmlTablePrinter prints event processing stats as a HTML tableHttpBasicAuthenticationFilter TODOHttpClientMessageDispatcher dispatches Mule events over HTTP.HttpClientMethodResponseToObject transforms a http client response
to a MuleMessage.HttpConnector provides a way of receiving and sending http requests
and responses.HttpConstants for request and response headersHttpMessageAdapter Wraps an incoming Http Request making the
payload and headers available as standard message adapter.HttpMessageReceiver is a simple http server that can be used to
listen for HTTP requests on a particular port.HttpRequestMessageAdapter is a Mule message adapter for
javax.servletHttpServletRequest objects.NameStringToChatString This is test class only for use with the
Hello world test application.HttpRequestWildcardFilter filters out wildcard URL expressions.HttpsConnector provides Https connectivityHttpsMessageReceiver is a Https server implementation used to
receive incoming requests over httpsRoutingException holds a reference to the current
message and te endpoint being routing to or from when the error occurred.
Entry.getCurrentState() for a component in an initialised
state.
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 to trigger an interceptor chain.InvalidSatsuma has no discoverable methodsInvocation represents a link in an interceptor chain.IsXmlFilter accepts a String or byte[] if its contents are valid
(well-formed) XML.inboundRouter instead.
inboundRouter instead.
InitialisationException should be thrown,
causing the Mule instance to shutdown. If the error is recoverable, say by
retrying to connect, a RecoverableException should be thrown.
There is no guarantee that by throwing a Recoverable exception that the Mule
instance will not shut down.
(non-Javadoc)
EntryPoint is avoid method or not
JMSMessageToObject Will convert a javax.jms.Message
or sub-type into an object by extracting the message payload.JXPathFilter evaluates an XPath expression against a W3C Document,
XML string, or Java bean and returns true if the result is as expected.org.mule.routing.filters.xml.JXPathFilter
instead.JXPathNormalizerInterceptor can be used as a simple pre/post
message transformer for a given component.JbiConnector can bind to a Jbi container allowing components to
send events via MuleJbiMessageAdapter translates a JBI NormalizedMessage to a
UMOMessageTcpMessageDispatcher will send transformed mule events over tcp.TcpMessageDispatcherFactory TODOJcaComponent Is the type of component used in Mule when embedded
inside an app server using JCA.JdmkAgent configures an Jdmk Http Adaptor for Jmx management,
statistics and configuration viewing of a Mule instance.ServletConnector is a channel adapter between Mule and a servlet
engine.HttpMessageReceiver is a simple http server that can be used to
listen for http requests on a particular portJiniMessageAdapter wraps a JavaSpaceMessage entry.Jms102bSupport is a template class to provide an abstraction to the
JMS 1.0.2b API specification.Jms11Support is a template class to provide an abstraction to to
the JMS 1.1 API specification.JmsClientAcknowledgeTransaction is a transaction implementation of
performing a message acknowledgement.JmsClientAcknowledgeTransactionFactory creates a JMS Client
Acknowledge Transaction using a JMS Message.JmsConnector is a JMS 1.0.2b compliant connector that can be used
by a Mule endpoint.JmsMessageAdapter allows a MuleEvent to access the
properties and payload of a JMS Message in a uniform way.JmsMessageDispatcher is responsible for dispatching messages to JMS
destinations.JmsMessageDispatcherFactory creates a message adapter that will
send JMS messagesJmsMessageUtils contains helper method for dealing with JMS
messages in Mule.JmsReplyToHandler will process a JMS replyTo or hand off to the
default replyTo handler if the replyTo is a URLJmsSelectorFilter is a wrapper for a JMS Selector.JmsSupport is an interface that provides a polymorphic facade to
the JMS 1.0.2b and 1.1 API specifications.JmsTransaction is a wrapper for a JMS local transaction.JmsTransactionFactory creates a JMS local transactionJmxAgent registers MUle Jmx management beans with an MBean
server.JmxManagementException is thrown by the Jmx agents if an error
occurs while executing an operationJndiContainerContext is a container implementaiton that exposes a
jndi context.JnpConnector uses the Java Naming protocol to bind to remote
objectsDefaultLenderService is responsible for contacting the relivant
banks depending on the amount of the loanLifecycle adds lifecycle methods start,
stop and dispose.LifecycleException TODOLifecycleInterceptor is a UMOInterceptor interface with two
additional lifecycle methods provided by Initialisable and
Disposable- LoanBroker - class org.mule.samples.loanbroker.esb.LoanBroker.
LoanBroker is the Service that starts the loan request process.- LoanBroker() -
Constructor for class org.mule.samples.loanbroker.esb.LoanBroker
-
- LoanBroker - interface org.mule.samples.loanbroker.service.LoanBroker.
LoanBroker is the Servie that starts the loan request process.- LoanConsumer - class org.mule.samples.loanbroker.LoanConsumer.
LoanConsumer is a loan broker client app that uses command line
prompts to obtain loan requests- LoanConsumer() -
Constructor for class org.mule.samples.loanbroker.LoanConsumer
-
- LoanConsumer(String) -
Constructor for class org.mule.samples.loanbroker.LoanConsumer
-
- LoanQuote - class org.mule.samples.loanbroker.LoanQuote.
LoanQuote is a loan quote from a bank- LoanQuote() -
Constructor for class org.mule.samples.loanbroker.LoanQuote
-
- LoanQuote - class org.mule.samples.loanbroker.esb.message.LoanQuote.
LoanQuote is a loan quote from a bank- LoanQuote() -
Constructor for class org.mule.samples.loanbroker.esb.message.LoanQuote
-
- LoanQuoteRequest - class org.mule.samples.loanbroker.esb.message.LoanQuoteRequest.
LoanQuoteRequest represents a customer request for a loan through a
loan broker- LoanQuoteRequest() -
Constructor for class org.mule.samples.loanbroker.esb.message.LoanQuoteRequest
-
- LoanQuoteRequestToCreditProfileArgs - class org.mule.samples.loanbroker.esb.transformers.LoanQuoteRequestToCreditProfileArgs.
- Extracts the customer information from the request into an array of arguments used
to invoke the Credit Agency Session bean
- LoanQuoteRequestToCreditProfileArgs() -
Constructor for class org.mule.samples.loanbroker.esb.transformers.LoanQuoteRequestToCreditProfileArgs
-
- LoanQuoteRequestToCustomer - class org.mule.samples.loanbroker.esb.transformers.LoanQuoteRequestToCustomer.
- Extracts the customer information from the request
- LoanQuoteRequestToCustomer() -
Constructor for class org.mule.samples.loanbroker.esb.transformers.LoanQuoteRequestToCustomer
-
- LoanRequest - class org.mule.samples.loanbroker.LoanRequest.
LoanRequest is the request sent by the the LoanBroker- LoanRequest() -
Constructor for class org.mule.samples.loanbroker.LoanRequest
-
- LoanRequest(Customer, double, int) -
Constructor for class org.mule.samples.loanbroker.LoanRequest
-
- Log4jAgent - class org.mule.management.agents.Log4jAgent.
Log4jAgent exposes the configuration of the Log4J instance running
in Mule for Jmx management- Log4jAgent() -
Constructor for class org.mule.management.agents.Log4jAgent
-
- 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
-
- libraries -
Variable in class org.mule.registry.impl.AbstractRegistryComponent
-
- licenseFileName -
Static variable in class org.mule.modules.boot.LicenseHandler
-
- licenseJarExists() -
Method in class org.mule.modules.boot.LicenseHandler
- This method checks to see if there is a license jar file already.
- 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
-
- listFiles() -
Method in class org.mule.providers.ftp.FtpMessageReceiver
-
- listJars(File, String) -
Method in class org.mule.modules.boot.DefaultMuleClassPathConfig
- Find and if necessary filter the jars for classpath.
- listSecurityServiceTypes() -
Static method in class org.mule.util.DebugUtils
-
- listeners -
Variable in class org.mule.extras.spring.events.MuleEventMulticaster
- The set of listeners for this Multicaster
- listeners -
Variable in class org.mule.impl.space.AbstractSpace
-
- load(String) -
Method in interface org.mule.registry.RegistryStore
-
- load(String) -
Method in class org.mule.registry.store.XmlRegistryStore
-
- 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.
- loadBeanDefinitions(DefaultListableBeanFactory) -
Method in class org.mule.extras.spring.config.MuleApplicationContext
-
- loadClass(String, boolean) -
Method in class org.mule.registry.ClassLoaderFactory.JbiClassLoader
-
- loadClass(String, Class) -
Static method in class org.mule.util.ClassUtils
- Load a class with a given name.
- loadConfig(String) -
Method in class org.mule.config.builders.AbstractDigesterConfiguration
- Attempt to load a configuration resource from the file system, classpath, or
as a URL, in that order.
- loadConfig(String) -
Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
- ConfigResource can be a url, a path on the local file system or a resource
name on the classpath Finds and loads the configuration resource by doing the
following - 1.
- loadInterpreter(URL) -
Method in class org.mule.components.script.AbstractScriptComponent
-
- loadInterpreter(String) -
Method in class org.mule.components.script.AbstractScriptComponent
-
- 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
-
- localTransactionCommitted(ConnectionEvent) -
Method in class org.mule.ra.DefaultConnectionManager
-
- localTransactionRolledback(ConnectionEvent) -
Method in class org.mule.ra.DefaultConnectionManager
-
- localTransactionStarted(ConnectionEvent) -
Method in class org.mule.ra.DefaultConnectionManager
-
- localXid -
Variable in class org.mule.util.xa.DefaultXASession
-
- locateServer -
Variable in class org.mule.management.agents.JmxAgent
- Should MBeanServer be discovered.
- log(String) -
Method in class org.mule.components.simple.LogComponent
-
- log(String) -
Method in interface org.mule.components.simple.LogService
-
- log -
Static variable in class org.mule.providers.soap.axis.extensions.MuleHttpSender
- Deprecated.
- logBoilerPlate(List) -
Method in class org.mule.util.MuleLogger
-
- logBoilerPlate(String[]) -
Method in class org.mule.util.MuleLogger
-
- logCSVSummary() -
Method in class org.mule.management.mbeans.StatisticsService
-
- logCSVSummary() -
Method in interface org.mule.management.mbeans.StatisticsServiceMBean
-
- 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
-
- logEvent(UMOServerNotification) -
Method in class org.mule.management.agents.JmxServerNotificationAgent
-
- logException(Throwable) -
Method in class org.mule.impl.AbstractExceptionListener
- Used to log the error passed into this Exception Listener
- logException(Exception) -
Method in class org.mule.providers.soap.axis.AxisServiceComponent
-
- 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.mbeans.StatisticsService
-
- 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.ManagementContext
-
- 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 -
Variable in class org.mule.components.script.AbstractScriptComponent
- logger used by this class
- logger -
Variable in class org.mule.components.script.jsr223.Scriptable
- 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 -
Variable in class org.mule.config.builders.AbstractDigesterConfiguration
- 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.MuleClasspathConfigurationBuilder
- Deprecated. logger used by this class
- logger -
Static variable in class org.mule.config.builders.MuleXmlConfigurationBuilder
- logger used by this class
- logger -
Static variable in class org.mule.config.builders.PlaceholderProcessor
- 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 -
Static variable in class org.mule.extras.acegi.filters.http.HttpBasicAuthenticationFilter
- logger used by this class
- logger -
Static variable in class org.mule.extras.client.MuleClient
- logger used by this class
- logger -
Static variable in class org.mule.extras.client.RemoteDispatcher
- logger used by this class
- logger -
Static variable in class org.mule.extras.pgp.KeyBasedEncryptionStrategy
-
- logger -
Static variable in class org.mule.extras.pgp.PGPKeyRingImpl
-
- logger -
Static variable in class org.mule.extras.pgp.filters.PGPSecurityFilter
-
- logger -
Static variable in class org.mule.extras.spring.SpringContainerContext
- logger used by this class
- logger -
Static variable in class org.mule.extras.spring.config.AutowireUMOManagerFactoryBean
- logger used by this class
- logger -
Variable in class org.mule.extras.spring.config.MuleResourceLoader
-
- logger -
Static variable in class org.mule.extras.spring.config.TransformerEditor
- logger used by this class
- logger -
Static variable in class org.mule.extras.spring.events.AsynchronousEventListener
- logger used by this class
- logger -
Static variable in class org.mule.extras.spring.events.MuleEventMulticaster
- 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 -
Variable in class org.mule.impl.space.AbstractSpace
- 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.management.agents.JmxAgent
- Logger used by this class.
- logger -
Variable in class org.mule.management.agents.RmiRegistryAgent
- logger used by this class
- logger -
Variable in class org.mule.management.mbeans.EndpointService
- logger used by this class
- logger -
Variable in class org.mule.management.mbeans.MuleService
- logger used by this class
- logger -
Static variable in class org.mule.management.mbeans.StatisticsService
- 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 -
Variable in class org.mule.providers.ejb.EjbMessageReceiver
-
- logger -
Static variable in class org.mule.providers.email.MailUtils
- The logger used for this class
- logger -
Variable in class org.mule.providers.email.filters.AbstractMailFilter
- logger used by this class
- logger -
Variable in class org.mule.providers.email.transformers.StringToEmailMessage
- logger used by this class
- logger -
Variable in class org.mule.providers.gs.space.GSSpaceFactory
- logger used by this class
- logger -
Static variable in class org.mule.providers.http.CookieHelper
- logger used by this class
- logger -
Variable in class org.mule.providers.http.HttpSessionHandler
- logger used by this class
- logger -
Variable in class org.mule.providers.http.servlet.AbstractReceiverServlet
- logger used by this class
- logger -
Variable in class org.mule.providers.jbi.components.AbstractJbiComponent
- logger used by this class
- logger -
Static variable in class org.mule.providers.jms.DefaultRedeliveryHandler
- logger used by this class
- logger -
Static variable in class org.mule.providers.jms.xa.ConnectionFactoryWrapper
-
- logger -
Variable in class org.mule.providers.quartz.jobs.MuleClientDispatchJob
- The logger used for this class
- logger -
Variable in class org.mule.providers.quartz.jobs.MuleClientReceiveJob
- The logger used for this class
- logger -
Variable in class org.mule.providers.quartz.jobs.MuleReceiverJob
- The logger used for this class
- logger -
Static variable in class org.mule.providers.rmi.RmiMessageDispatcher
-
- 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 -
Static variable in class org.mule.providers.soap.axis.AxisInitialisationCallback
- logger used by this class
- logger -
Static variable in class org.mule.providers.soap.axis.AxisServiceComponent
- logger used by this class
- logger -
Static variable in class org.mule.providers.soap.axis.extensions.MuleSoapHeadersHandler
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.axis.extensions.UniversalSender
- logger used by this class
- logger -
Static variable in class org.mule.providers.soap.glue.GlueInitialisationCallback
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.xfire.XFireServiceComponent
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.xfire.transport.MuleLocalChannel
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.xfire.transport.MuleLocalTransport
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.xfire.transport.MuleUniversalChannel
- logger used by this class
- logger -
Variable in class org.mule.providers.soap.xfire.transport.MuleUniversalTransport
- logger used by this class
- logger -
Variable in class org.mule.providers.space.SpaceMessageDispatcher
- logger used by this class
- logger -
Static variable in class org.mule.providers.xmpp.XmppMessageDispatcher
- logger used by this class
- logger -
Variable in class org.mule.ra.DefaultMuleConnectionFactory
- logger used by this class
- logger -
Variable in class org.mule.ra.MuleManagedConnectionFactory
- logger used by this class
- logger -
Variable in class org.mule.ra.MuleResourceAdapter
- logger used by this class
- logger -
Variable in class org.mule.routing.AbstractCatchAllStrategy
- logger used by this class
- logger -
Variable in class org.mule.routing.filters.WildcardFilter
-
- logger -
Variable in class org.mule.routing.filters.xml.JXPathFilter
-
- 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 -
Variable in class org.mule.routing.outbound.AbstractRecipientList
- 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.AbstractResponseRouter
-
- logger -
Static variable in class org.mule.routing.response.ResponseMessageRouter
- logger used by this class
- logger -
Static variable in class org.mule.samples.loanbroker.AsyncLoanBroker
- logger used by this class
- logger -
Static variable in class org.mule.samples.loanbroker.Bank
- logger used by this class
- logger -
Variable in class org.mule.samples.loanbroker.DefaultLenderService
- logger used by this class
- logger -
Static variable in class org.mule.samples.loanbroker.SyncLoanBroker
- logger used by this class
- logger -
Static variable in class org.mule.samples.loanbroker.esb.bank.Bank
- logger used by this class
- logger -
Static variable in class org.mule.samples.voipservice.client.VoipConsumer
-
- logger -
Static variable in class org.mule.samples.voipservice.routers.PaymentValidationResponseAggregator
-
- logger -
Static variable in class org.mule.samples.voipservice.service.AddressValidationService
-
- logger -
Static variable in class org.mule.samples.voipservice.service.BankAgencyService
-
- logger -
Static variable in class org.mule.samples.voipservice.service.CreditAgencyService
-
- logger -
Static variable in class org.mule.samples.voipservice.service.PaymentValidationService
-
- logger -
Static variable in class org.mule.samples.voipservice.service.SyncVoipBroker
-
- logger -
Variable in class org.mule.tck.AbstractMuleTestCase
-
- logger -
Variable in class org.mule.tck.functional.FunctionalTestComponent
-
- logger -
Variable in class org.mule.transaction.AbstractTransaction
-
- logger -
Static variable in class org.mule.transaction.TransactionCoordination
-
- 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.transformers.wire.TransformerPairWireFormat
- 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.properties.JXPathPropertyExtractor
- logger used by this class
- logger -
Variable in class org.mule.util.properties.PayloadPropertyExtractor
- 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
- login() -
Method in class org.mule.extras.jaas.loginmodule.DefaultLoginModule
- This method attempts to login the user by checking his credentials against
those of the authorised users.
- logout() -
Method in class org.mule.extras.jaas.loginmodule.DefaultLoginModule
- Returns true when authentication succeeds or false when it fails
- 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
-
- lookupDispatcher(String) -
Method in class org.mule.providers.AbstractConnector
-
- 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.providers.soap.axis.extensions.UniversalSender
-
- 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.
- lookupEndpointByAddress(String) -
Method in class org.mule.MuleManager
- {@inheritDoc}
- 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
-
- lookupReceiver(String) -
Method in class org.mule.providers.AbstractConnector
-
- 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.
MailMessageAdapter is a wrapper for a javax.mail.Message.MailSubjectRegExFilter applies a regular expression to a Mail
Message subject.Main Executes the LoanBroker ESB applicationMalformedEndpointException is thrown by the MuleEndpointURI class
if it fails to parse a UrlManagementException is a general exception thrown by management
extensionsManagementNotification 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.ModelService exposes service information and actions on the Mule
ModelModelServiceMBean JMX Service interface for the UMOModelMuleActivationSpec defines the contract between a Message Driven
Bean (MDB) and the Mule Resource Adapter.MuleAdminAgent manages the server endpoint that receives Admin and
remote client requestsMuleApplicationContext is A Simple extension Application context
that allows rosurces to be loaded from the Classpath of file system using the
MuleBeanDefinitionReader.MuleApplicationEvent is an Spring ApplicationEvent used to wrap a
MuleEventMuleAuthentication TODOMuleBeanDefinitionReader Is a custom Spring Bean reader that will
apply a transformation to Mule Xml configuration files before loading bean
definitions allowing Mule Xml config to be parsed as Spring configuration.MuleClient is a simple interface for Mule clients to send and
receive events from a Mule Server.MuleConfigProvider is needed because the Simple Provider does not
list services in the defaultConfigurationMuleConfiguration holds the runtime configuration specific to the
MuleManager.MuleConfigurationService exposes the MuleConfiguration settings as
a management serviceMuleConfigurationServiceMBean is a JMx service interface for the
Mule server configurationMuleConnection defines the client connection methods for the JCA
CCI contractMuleConnectionFactory defines the connection factory interface that
the RA clients will obtain a reference to.MuleConnectionRequestInfo TODOMuleContainerContext 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 header.MuleDescriptor 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.MuleEndpointKey TODOMuleEndpointURI 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.MuleEventListener is a interface that identifies an object as
wanting to receive Mule EventsMuleEventMulticaster is an implementation of a Spring
ApplicationeventMulticaster.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 messagesMuleManagedConnection TODOMuleManagedConnectionFactory TODOMuleManagedConnectionMetaData TODOMuleManager 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.MuleMsgProvider Is an Axis service endpoint that builds services
from Mule managed componentsMuleObjectHelper is a helper class to assist in finding mule server
objects, such as endpoint and transformersMuleObjectNameProcessor is used to set spring ids to Mule object
names so the the bean id and name property on the object don't both have to be
set.ObjectServiceFactory.
MuleProperties is a set of constants pertaining to Mule system
properties.MuleProxy is a proxy to a UMO.MuleProxyListener is a generic listent proxy that can be used to
foward calls as Mule events from any Observer/Observerable implementation.MuleRESTReceiverServlet is used for sending a receiving events from
the Mule server via a serlet container.MuleProvider Is an Axis service endpoint that builds services from
Mule managed componentsMuleResourceAdapter TODOMuleResourceLoader is a custom Spring resource loader that calls
standard Mule methods for loading resource files.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 instance.MuleServer is a simple application that represents a local Mule
Server daemon.MuleService exposes certain Mule server functions for managementMuleServiceMBean is a JMX service interface for the UMOManagerMuleSession manages the interaction and distribution of events for
Mule UMOs.MuleSoapHeaders is a helper class for extracting and writing Mule
header properties to s Soap messageMuleSoapHeadersHandler is an Axis handler that can read and write
Mule header properties to a Soap messageMuleSubscriptionEventListener is a Spring ApplicationListener that
is used to register interest about Mule events.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 Geronimo.MuleXmlBuilderContextListener is a bootstrap listener used to
construct a MuleManager instance.MuleXmlConfigurationBuilder is a configuration parser that builds a
MuleManager instance based on a mule xml configration file defined in the
mule-configuration.dtd.MultiContainerContext is a container that hosts other containers
from which components are queried.MulticastConnector can dispatch mule events using ip multicastingMulticastMessageAdapter TODOMulticastMessageDispatcher dispatches events to a multicast addressMulticastMessageDispatcherFactory creates a dispatcher for
broadcasting events over multicastMulticastMessageReceiver TODO (document class)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.Mx4jAgent configures an Mx4J Http Adaptor for Jmx management,
statistics and configuration viewing of a Mule instance..PropertiesUtils.registerMaskedPropertyName(String).
NameString TODO (document class)NameStringToChatString cnverts from a NameString object to a
ChatString objectNoActionTransformer 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 accept.NullPayload represents a null event payloadNumberUtils contains useful methods for manipulating numbers.MuleRPCProvider.
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.ObjectToHttpClientMethodRequest transforms a UMOMessage into a
HttpClient HttpMethod that represents an HttpRequest.ObjectToJMSMessage will convert any object to a
javax.jms.Message or sub-type into an object.ObjectToString transformer is useful for debugging.ObjectToXml converts any object to xml using Xstream.MuleProxy is a proxy to a UMO.OrFilter accepts if the leftFilter or rightFilter filter accept.StreamMessageAdapter wraps an java.io.OutputStream and allows meta
information to be associated with the stream.OutboundMessageRouter 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.PeopleService is a test service that returns complex typesPerson part of the PeopleServicePicoContainerContext is a Pico Context that can expose pico-managed
components for use in the Mule framework.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.Pop3Connector is used to connect and receive mail from a POP3
mailboxPop3MessageDispatcher For Pop3 connections the dispatcher can only
be used to receive message (as opposed to listening for them).Pop3MessageDispatcherFactory creates a Pop3 Message dispatcher.Pop3MessageReceiver polls a POP3 mailbox for messages, removes the
messages and routes them as events into Mule.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.MapUtils.toString(Map, boolean) instead
QNameConverter TODO document properly; see QNameConverterTestCase
for nowQueue 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
managerEntry.getCurrentState() for a running component.
RaHelper is a collection of helper methods used by this RA
implementationReaderResource 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.RedeliveryHandler is used to control how redelivered messages are
processed by a connector.RegExFilter is used to match a String argument against a regular
expression.RemoteDispatcher is used to make and receive requests to a remote
Mule instance.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.RmiConnector can bind or send to a given RMI port on a given host.RmiContainerContext is a container implementaiton that allows RMi
objects to be referenced either as components or properties on componentsRmiMessageDispatcher will send transformed mule events over
RMI-JRMP.RoutePathNotFoundException is thrown if a routing path for an event
cannot be found.RouterStatistics todoRouterStats TODORouterStatsMBean TODORoutingException is a base class for all 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.
#repeat(String, int) but with a single character as argument.
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.
Entry.getCurrentState() for a shutdown component.
Entry.getCurrentState() for a stopped component.
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
instance.ServiceProxy is a proxy that wraps a soap endpointUri to look like
a Web service.ServletConnector is a channel adapter between Mule and a servlet
engine.ServletMessageReceiver is a receiver that is invoked from a Servlet
when an event is received.SessionException is thrown when errors occur in the MuleSession or
Seession ManagerXMLEntityCodec instead.XmlEntityDecoder insteadXmlEntityEncoder insteadSimpleFilenameParser understands a limited set of tokens, namely
${DATE} : the currrent date in the format dd-MM-yy_HH-mm-ss.SS
${DATE:yy-MM-dd} : the current date using the specified format
${SYSTIME} : The current system time milliseconds
${UUID} : A generated Universally unique id
${ORIGINALNAME} : The origial file name if the file being written was read
from another location
${COUNT} : An incremental counter
${SimplePrinter Default stats printerSmtpConnector is used to connect to and send data to an SMTP mail
serverSmtpMessageDispatcher will dispatch Mule events as Mime email
messages over an SMTP gatewaySmtpMessageDispatcherFactory creates an instance of an SmtpMessage
dispatcher used for sending email events via an SMTP gatewaySoapServiceFinder finds a the connector service to use by checking
the classpath for jars required for each of the soap connector implementationsSocketEndpointBuilder builds an endpointUri based on host and port
onlyInterruptedException from
the underlying space storeSpaceMessageDispatcher Provides generic connectivity to 'Spaces'
that implement the Mule Space Api, i.e.SpaceMessageDispatcherFactory creates a space Message DisaptcherSpaceMessageReceiver registers a listener on a Space, which can be
a JavaSpace, Rio space, JCache implementation of an internal Mule space.SpringConfigurationBuilder Enables Mule to be loaded from as Spring
context.SpringContainerContext is a Spring Context that can expose
spring-managed components for use in the Mule framework.TcpConnector can bind or sent to a given tcp port on a given host.TcpMessageDispatcher will send transformed mule events over tcp.SslMessageDispatcherFactory creates SslMessageDispatcher instancesSslMessageReceiver acts like a tcp server to receive socket
requests using SSL.Startable TODO (document class)StaticRecipientList is used to dispatch a single event to multiple
recipients over the same transport.Statistics todoStatisicsService exposes Mule processing statisticsStatisticsServiceMBean is a JMX interfaces for querying Mule event
processing statisticsStoppable TODO (document class)StreamConnector can send and receive Mule events over IO streams.StreamMessageAdapter TODO documentStreamMessageDispatcher is a simple stream dispatcher that obtains
a stream from the Stream Connector to write to.StreamMessageDispatcherFactory creates a Stream dispatcher suitable
for writing to fixed streams such as System.in or System.out.StreamMessageReceiver is a listener for events from Mule components
which then simply passes the events on to the target components.StringMessageHelper contains some useful methods for formatting
message strings for logging or exceptions.StringToByteArray converts a string into a byte arrayStringToEmailMessage will convert a String to a JavaMail Message,
using the String as the contents.StringToNameString converts from a String to a NameString objectStringUtils contains useful methods for manipulating Strings.SyncLoanBroker is a synchronous Loan Broker that makes the calls to
various components through the event context synchronously.SystemStreamConnector connects to the System streams in and out by
default and add some basic fuctionality for writing out prompt messages.handleRedelivery() is called
handleRedelivery() is called
MuleManager.
MuleManager.
#expression evaluation, set
this to false.
setExpectedValue(String expectedValue).
StringUtils, but
additionally trims whitespace from the result tokens.
MuleManager.
MuleManager.
MuleManager which stops all sessions and connectors
Transformer
implementation class to use, if no other can be found.
TcpConnector can bind or sent to a given tcp port on a given host.TcpMessageAdapter TODOTcpMessageDispatcher will send transformed Mule events over TCP.TcpMessageDispatcherFactory TODOTcpMessageReceiver acts like a tcp server to receive socket
requests.TcpStreamingMessageReceiver establishes a tcp client connection to
an external server and reads the streaming data.TemplateParser is a simple string parser that will substitute
tokens in a string with values supplied in a Map.TestConnector us a mock connectorTestDefaultLifecycleAdapter TODO (document class)TestDefaultLifecycleAdapterFactory TODO (document class)TestDependentObject is used as a mock dependency for an objectTestEntryPointResolver TODO (document class)TestExceptionStrategy TODOTestResponseAggregator is a mock response Agrregator object used
for testing configurationTestServiceComponent is a test WebServices component.TestTransactionFactory TODOTestTransactionManagerFactory TODOThreadingProfile 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.TlsConnector Provides TLS connectionsTooManySatisfiableMethodsException is thrown by EntryPointResolvers
when the component passed has more than one method that meets 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 progress.TransactionNotInProgressException TODO (document class)TransformerConverter will obtain a transformer name and convert it
to a transformer instance by looking up the transformer from the
MuleManager.TransformerEditor is used to convert Transformer names into
transformer ObjectsTransformerException is a simple exception that is thrown by
transformers.TransformerReference maintains a transformer reference.Class as
element type.
#toString(Object) but considers at most maxElements
values; overflow is indicated by an appended "[..]" ellipsis.
CollectionUtils.toString(Collection, int, boolean) with false
for newline.
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.UMOManagerFactoryBean is a Spring FactoryBean used for creating a
MuleManager from a Spring context.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.UMOMessageToHttpResponse converts a UMOMEssage into an Http
response.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
methodsEntry.getCurrentState() for a component in an unknown
state.
Base64Encoder transforms strings or byte arrays into Base64 encoded
stringBase64Encoder transforms strings or byte arrays into UU encoded
stringUUID Generates a UUID using the JUG libraryUdpConnector can send and receive Mule events as Datagram packets.UdpMessageAdapterUdpMessageDispatcher is responsible for dispatching MuleEvents as
UDP packets on the networkUdpMessageDispatcherFactory creates a dispatcher for sending UDP
packets.UdpMessageReceiver receives UDP message packets.UnauthorisedException 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.
VMConnector A simple endpoint wrapper to allow a Mule component to
be accessed from an endpointVMMessageAdapter provides a common abstraction of Mule Event
message.VMMessageDispatcher is used for providing in memory interaction
between components.VMMessageDispatcherFactory creates an in-memory event dispatcherVMMessageReceiver is a listener of events from a mule component
which then simply passes the events on to the target component.WSDDJavaMuleProvider is a factory class for creating the
MuleProviderWebappMuleXmlConfigurationBuilder will first try and load config
resources from the Servlet context.WildcardFilter is used to match Strings against wildcards.WorkExecutor TODOWorkerContext TODOWriterMessageAdapter wraps a java.io.StringWriter and allows meta
information to be associated with the Writer.WsdlServiceFinder finds a the connector service to use by checking
the classpath for jars required for each of the soap connector implementationsBase64.OutputStream.write(int) repeatedly until len bytes are
written.
XFireMessageAdapter wraps an XFire MessageContext, reading
attachments and Mule headers.XaTransaction represents an XA transaction in Mule.XaTransactionFactory Is used to create/retrieve a Transaction from
a transaction manager configured on the MuleManager. XmlToDQMessage will convert an XML string to a DQMessage.XmlToDomDocument transforms a XML String to org.w3c.dom.Document.XmlToObject converts xml created by the ObjectToXml transformer in
to a java object graph.XmppAndFilter an Xmpp AND filterXmppConnector TODOXmppFromContainsFilter is an Xmpp FromContainsfilter adapter.XmppMessageAdapter wraps an Smack XMPP packetXmppMessageDispatcher allows Mule events to be sent and received
over XmppXmppMessageDispatcherFactory creates a dispatcher responsible for
writing Xmpp packets to a an Jabber chatXmppMessageReceiver is responsible for receiving Mule events over XMPP.XmppMessageTypeFilter is an Xmpp MessageTypeFilter adapter.XmppAndFilter an Xmpp AND filterXmppAndFilter an Xmpp OR filterXmppPacketIDFilter is an Xmpp PacketIDFilter adapter.XmppPacketTypeFilter is an Xmpp PacketTypeFilter adapter.XmppThreadFilter is an Xmpp ThreadFilter adapter.XmppToContainsFilter is an Xmpp ToContainsfilter adapter.XsltTransformer performs an XSLT transform on a DOM (or other
XML-ish) object.
|
|||||||||||
| PREV NEXT | FRAMES NO FRAMES | ||||||||||