Uses of Interface
org.mule.umo.UMOMessage

Packages that use UMOMessage
org.mule.components.builder   
org.mule.components.rest   
org.mule.components.script.jsr223   
org.mule.examples.loanbroker.routers   
org.mule.extras.client Simple interface for Mule clients to send and receive events from local or remote Mule Servers. 
org.mule.impl The Mule implementation of the Universal Message Objects(tm) API specification. 
org.mule.impl.internal.admin Admin components and Agents used to control and Monitor Mule 
org.mule.impl.internal.notifications Internal server notification types fired via the MuleManager. 
org.mule.impl.model   
org.mule.impl.model.direct   
org.mule.impl.model.pipeline   
org.mule.impl.model.seda   
org.mule.impl.model.seda.optimised   
org.mule.impl.model.streaming   
org.mule.interceptors Contains default UMOInterceptor implementations that can be applied to Mule managed components. 
org.mule.providers Contains Abstract classes providing common functionality for all Mule providers. 
org.mule.providers.bpm   
org.mule.providers.bpm.jbpm   
org.mule.providers.email Provides pop3, smtp and imap connectivity for Mule
org.mule.providers.email.filters   
org.mule.providers.file Provides file transport in the form of a directory listeners and file dispatchers. 
org.mule.providers.file.filters Filename filters used to filter on a listening directory. 
org.mule.providers.ftp   
org.mule.providers.http Provides http transport including proxy support. 
org.mule.providers.http.servlet   
org.mule.providers.jbi Allows JBI components to interact with Mule. 
org.mule.providers.jbi.components   
org.mule.providers.jdbc Provides jdbc transport. 
org.mule.providers.jms Provides Jms transport connectivity with support for all Jms features. 
org.mule.providers.jms.filters   
org.mule.providers.jms.transformers Contains transformers to convert to and from different javax.jms.Message types 
org.mule.providers.oracle.jms   
org.mule.providers.quartz   
org.mule.providers.rmi   
org.mule.providers.soap.axis Provides an Axis soap transport for Mule
org.mule.providers.soap.xfire   
org.mule.providers.stream   
org.mule.providers.tcp Provides tcp connectivity for Mule
org.mule.providers.udp Provides Udp connectivity for Mule
org.mule.providers.vm A connector implementation allowing events to be passed between Mule sessions via in-memory queues. 
org.mule.providers.xmpp   
org.mule.providers.xmpp.filters   
org.mule.ra A Resource Adapter implementation that allows a Mule instance to be deployed to a J2ee application server and exposes Mule services via the JCA connector architecture. 
org.mule.routing Defines the core routing patterns supported by mule. 
org.mule.routing.filters Filters are often used by routers to determine if the event should be accepted by the router. 
org.mule.routing.filters.logic Filters that allow other filters to be combined. 
org.mule.routing.filters.xml Filters that apply specifically to xml using xml querying mechanisms. 
org.mule.routing.inbound Inbound router implementation as described in the Enterprise Integration Patterns book. 
org.mule.routing.nested   
org.mule.routing.outbound Outbound router implementation as described in the Enterprise Integration Patterns book. 
org.mule.routing.response Response router implementations that enable asynchronous event processing in request /response messaging requests. 
org.mule.samples.voipservice.routers   
org.mule.samples.voipservice.service   
org.mule.tck.testmodels.mule   
org.mule.umo The Universal Message Object(tm) API provides a way for components to interact without needing to know about the protocol or delivery mechanisms of information passed between them 
org.mule.umo.provider Contains the interfaces that comprise a provider implementation. 
org.mule.umo.routing Interfaces that define inbound and outbound routing API. 
org.mule.umo.security Security API for authentication and authorisation. 
 

Uses of UMOMessage in org.mule.components.builder
 

Methods in org.mule.components.builder with parameters of type UMOMessage
 Object MessageBuilder.buildMessage(UMOMessage request, UMOMessage response)
           
 Object ReflectionMessageBuilder.buildMessage(UMOMessage request, UMOMessage response)
           
 

Constructors in org.mule.components.builder with parameters of type UMOMessage
MessageBuilderException(Message message, UMOMessage umoMessage)
           
MessageBuilderException(Message message, UMOMessage umoMessage, Throwable cause)
           
MessageBuilderException(UMOMessage umoMessage, Throwable cause)
           
 

Uses of UMOMessage in org.mule.components.rest
 

Methods in org.mule.components.rest with parameters of type UMOMessage
protected  void RestServiceWrapper.handleException(RestServiceException e, UMOMessage result)
           
protected  boolean RestServiceWrapper.isErrorPayload(UMOMessage message)
           
 

Constructors in org.mule.components.rest with parameters of type UMOMessage
RestServiceException(Message message, UMOMessage umoMessage)
           
RestServiceException(Message message, UMOMessage umoMessage, Throwable cause)
           
 

Uses of UMOMessage in org.mule.components.script.jsr223
 

Methods in org.mule.components.script.jsr223 with parameters of type UMOMessage
 Object ScriptMessageBuilder.buildMessage(UMOMessage request, UMOMessage response)
           
protected  void ScriptMessageBuilder.populateBindings(javax.script.Bindings namespace, UMOMessage request, UMOMessage response)
           
 

Uses of UMOMessage in org.mule.examples.loanbroker.routers
 

Methods in org.mule.examples.loanbroker.routers that return UMOMessage
protected  UMOMessage BankQuotesResponseAggregator.aggregateEvents(EventGroup events)
          This method is invoked if the shouldAggregate method is called and returns true.
static UMOMessage BankQuotesAggregationLogic.aggregateEvents(EventGroup events)
           
protected  UMOMessage BankQuotesInboundAggregator.aggregateEvents(EventGroup events)
          This method is invoked if the shouldAggregate method is called and returns true.
 

Uses of UMOMessage in org.mule.extras.client
 

Methods in org.mule.extras.client that return UMOMessage
protected  UMOMessage RemoteDispatcher.dispatchAction(AdminNotification action, boolean synchronous, int timeout)
           
protected  UMOMessage RemoteDispatcher.doToRemote(String endpoint, Object payload, Map messageProperties, boolean synchronous, int timeout)
           
protected  UMOMessage RemoteDispatcher.doToRemoteComponent(String component, Object payload, Map messageProperties, boolean synchronous)
           
 UMOMessage MuleClient.receive(String url, long timeout)
          Will receive an event from an endpointUri determined by the url
 UMOMessage MuleClient.receive(String url, String transformers, long timeout)
          Will receive an event from an endpointUri determined by the url
 UMOMessage MuleClient.receive(String url, UMOTransformer transformer, long timeout)
          Will receive an event from an endpointUri determined by the url
 UMOMessage RemoteDispatcher.receiveRemote(String endpoint, int timeout)
           
 UMOMessage MuleClient.send(String url, Object payload, Map messageProperties)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 UMOMessage MuleClient.send(String url, Object payload, Map messageProperties, int timeout)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 UMOMessage MuleClient.send(String url, UMOMessage message)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 UMOMessage MuleClient.send(String url, UMOMessage message, int timeout)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 UMOMessage MuleClient.sendDirect(String component, String transformers, Object payload, Map messageProperties)
          sends an event synchronously to a components
 UMOMessage MuleClient.sendDirect(String component, String transformers, UMOMessage message)
          sends an event synchronously to a components
 UMOMessage RemoteDispatcher.sendRemote(String endpoint, Object payload, Map messageProperties)
           
 UMOMessage RemoteDispatcher.sendRemote(String endpoint, Object payload, Map messageProperties, int timeout)
           
 UMOMessage RemoteDispatcher.sendToRemoteComponent(String component, Object payload, Map messageProperties)
          sends an event synchronously to a components on a remote Mule instance.
 UMOMessage AbstractEventTransformer.transform(Object src, Method method)
           
 

Methods in org.mule.extras.client with parameters of type UMOMessage
 void MuleClient.dispatch(String url, UMOMessage message)
          Dispatches an event asynchronously to a endpointUri via a mule server.
 void MuleClient.dispatchDirect(String component, UMOMessage message)
          dispatches an event asynchronously to the components
protected  UMOEvent MuleClient.getEvent(UMOMessage message, String uri, boolean synchronous, boolean streaming)
          Packages a mule event for the current request
 UMOMessage MuleClient.send(String url, UMOMessage message)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 UMOMessage MuleClient.send(String url, UMOMessage message, int timeout)
          Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
 FutureMessageResult MuleClient.sendAsync(String url, UMOMessage message)
          sends an event request to a Url, making the result of the event trigger available as a Future result that can be accessed later by client code.
 FutureMessageResult MuleClient.sendAsync(String url, UMOMessage message, int timeout)
          sends an event request to a Url, making the result of the event trigger available as a Future result that can be accessed later by client code.
 UMOMessage MuleClient.sendDirect(String component, String transformers, UMOMessage message)
          sends an event synchronously to a components
 FutureMessageResult MuleClient.sendDirectAsync(String component, String transformers, UMOMessage message)
          sends an event to a components on a local Mule instance, while making the result of the event trigger available as a Future result that can be accessed later by client code.
protected  void RemoteDispatcher.setCredentials(UMOMessage message)
           
protected  void RemoteDispatcher.updateContext(UMOMessage message, UMOEndpoint endpoint, boolean synchronous)
           
 

Uses of UMOMessage in org.mule.impl
 

Classes in org.mule.impl that implement UMOMessage
 class MuleMessage
          MuleMessage is a wrapper that contains a payload and properties associated with the payload.
 

Methods in org.mule.impl that return UMOMessage
static UMOMessage OptimizedRequestContext.criticalRewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
static UMOMessage OptimizedRequestContext.criticalWriteResponse(UMOMessage message)
           
 UMOMessage InterceptorsInvoker.execute()
           
 UMOMessage MuleEventContext.getMessage()
          Returns the message payload for this event
 UMOMessage MuleEvent.getMessage()
           
 UMOMessage DefaultLifecycleAdapter.intercept(Invocation invocation)
           
protected static UMOMessage RequestContext.internalRewriteEvent(UMOMessage message, boolean safe, boolean required)
           
protected static UMOMessage RequestContext.internalWriteResponse(UMOMessage message, boolean safe, boolean required)
           
protected static UMOMessage RequestContext.newMessage(UMOMessage message, boolean safe, boolean required)
           
 UMOMessage ImmutableMuleEndpoint.receive(long timeout)
           
 UMOMessage MuleSession.receiveEvent(String endpointName, long timeout)
           
 UMOMessage MuleEventContext.receiveEvent(String endpointName, long timeout)
          Requests a synchronous receive of an event on the component
 UMOMessage MuleEventContext.receiveEvent(UMOEndpoint endpoint, long timeout)
          Requests a synchronous receive of an event on the component
 UMOMessage MuleEventContext.receiveEvent(UMOEndpointURI endpointUri, long timeout)
          Requests a synchronous receive of an event on the component
 UMOMessage MuleSession.receiveEvent(UMOImmutableEndpoint endpoint, long timeout)
           
static UMOMessage RequestContext.rewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
 UMOMessage ImmutableMuleEndpoint.send(UMOEvent event)
           
 UMOMessage MuleEventContext.sendEvent(Object message)
          This will send an event via the configured outbound router on the component
 UMOMessage MuleSession.sendEvent(UMOEvent event)
           
 UMOMessage MuleSession.sendEvent(UMOMessage message)
           
 UMOMessage MuleEventContext.sendEvent(UMOMessage message)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleSession.sendEvent(UMOMessage message, String endpointName)
           
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, UMOEndpointURI endpointUri)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpointUri configured for the event
 UMOMessage MuleSession.sendEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
           
static UMOMessage OptimizedRequestContext.unsafeRewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
static UMOMessage OptimizedRequestContext.unsafeWriteResponse(UMOMessage message)
           
static UMOMessage RequestContext.writeResponse(UMOMessage message)
           
 

Methods in org.mule.impl with parameters of type UMOMessage
protected static void RequestContext.combineProperties(UMOEvent event, UMOMessage message)
           
 UMOEvent MuleSession.createOutboundEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOEvent previousEvent)
           
static UMOMessage OptimizedRequestContext.criticalRewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
static UMOMessage OptimizedRequestContext.criticalWriteResponse(UMOMessage message)
           
 void MuleSession.dispatchEvent(UMOMessage message)
           
 void MuleEventContext.dispatchEvent(UMOMessage message)
          This will dispatch an event asynchronously via the configured outbound endpoint on the component for this session
 void MuleSession.dispatchEvent(UMOMessage message, String endpointName)
           
 void MuleEventContext.dispatchEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 void MuleEventContext.dispatchEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 void MuleEventContext.dispatchEvent(UMOMessage message, UMOEndpointURI endpointUri)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpointUri configured for the event
 void MuleSession.dispatchEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
           
protected  Object AbstractExceptionListener.getErrorMessagePayload(UMOMessage message)
           
abstract  void AbstractExceptionListener.handleMessagingException(UMOMessage message, Throwable e)
          A messaging exception is thrown when an excpetion occurs during normal message processing.
 void DefaultExceptionStrategy.handleMessagingException(UMOMessage message, Throwable t)
           
abstract  void AbstractExceptionListener.handleRoutingException(UMOMessage message, UMOImmutableEndpoint endpoint, Throwable e)
          A routing exception is thrown when an excpetion occurs during normal message processing A RoutingException holds a reference to the current message and te endpoint being routing to or from when the error occurred.
 void DefaultExceptionStrategy.handleRoutingException(UMOMessage message, UMOImmutableEndpoint endpoint, Throwable t)
           
protected static UMOMessage RequestContext.internalRewriteEvent(UMOMessage message, boolean safe, boolean required)
           
protected static UMOMessage RequestContext.internalWriteResponse(UMOMessage message, boolean safe, boolean required)
           
protected  void AbstractExceptionListener.logFatal(UMOMessage message, Throwable t)
          Logs a fatal error message to the logging system.
protected  void DefaultComponentExceptionStrategy.logFatal(UMOMessage message, Throwable t)
           
protected static UMOMessage RequestContext.newMessage(UMOMessage message, boolean safe, boolean required)
           
protected  void MuleSession.processResponse(UMOMessage response)
          Once an event has been processed we need to romove certain properties so that they not propagated to the next request
 void MuleSessionHandler.retrieveSessionInfoFromMessage(UMOMessage message, UMOSession session)
           
 void NullSessionHandler.retrieveSessionInfoFromMessage(UMOMessage message, UMOSession session)
           
static UMOMessage RequestContext.rewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
protected  void AbstractExceptionListener.routeException(UMOMessage message, UMOImmutableEndpoint failedEndpoint, Throwable t)
          Routes the current exception to an error endpoint such as a Dead Letter Queue (jms) This method is only invoked if there is a UMOMessage available to dispatch.
protected  void DefaultComponentExceptionStrategy.routeException(UMOMessage message, UMOImmutableEndpoint failedEndpoint, Throwable t)
           
 UMOMessage MuleSession.sendEvent(UMOMessage message)
           
 UMOMessage MuleEventContext.sendEvent(UMOMessage message)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleSession.sendEvent(UMOMessage message, String endpointName)
           
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage MuleEventContext.sendEvent(UMOMessage message, UMOEndpointURI endpointUri)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpointUri configured for the event
 UMOMessage MuleSession.sendEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
           
 FutureMessageResult MuleEventContext.sendEventAsync(UMOMessage message, int timeout)
          sends an event request via the configured outbound router for this component.
 FutureMessageResult MuleEventContext.sendEventAsync(UMOMessage message, String endpointName, int timeout)
          sends an event request via the configured outbound router for this component.
 FutureMessageResult MuleEventContext.sendEventAsync(UMOMessage message, UMOEndpointURI endpointUri, int timeout)
          sends an event request via the configured outbound router for this component.
 void MuleSessionHandler.storeSessionInfoToMessage(UMOSession session, UMOMessage message)
           
 void NullSessionHandler.storeSessionInfoToMessage(UMOSession session, UMOMessage message)
           
static UMOMessage OptimizedRequestContext.unsafeRewriteEvent(UMOMessage message)
          Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
static UMOMessage OptimizedRequestContext.unsafeWriteResponse(UMOMessage message)
           
static UMOMessage RequestContext.writeResponse(UMOMessage message)
           
 

Constructors in org.mule.impl with parameters of type UMOMessage
FailedToQueueEventException(Message message, UMOMessage umoMessage, UMOComponent component)
           
FailedToQueueEventException(Message message, UMOMessage umoMessage, UMOComponent component, Throwable cause)
           
FailedToQueueEventException(UMOMessage umoMessage, UMOComponent component, Throwable cause)
           
InterceptorsInvoker(List interceptors, MuleDescriptor descriptor, UMOMessage message)
           
InterceptorsInvoker(List interceptors, UMOImmutableDescriptor descriptor, UMOMessage message)
           
MuleEvent(UMOMessage message, UMOEvent rewriteEvent)
          A helper constructor used to rewrite an event payload
MuleEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOComponent component, UMOEvent previousEvent)
          Properties cache that only reads properties once from the inbound message and merges them with any properties on the endpoint.
MuleEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOSession session, boolean synchronous)
           
MuleEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOSession session, boolean synchronous, ResponseOutputStream outputStream)
          Contructor.
MuleEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOSession session, String eventId, boolean synchronous)
          Contructor.
MuleSession(UMOMessage message, UMOSessionHandler requestSessionHandler)
           
MuleSession(UMOMessage message, UMOSessionHandler requestSessionHandler, UMOComponent component)
           
 

Uses of UMOMessage in org.mule.impl.internal.admin
 

Methods in org.mule.impl.internal.admin with parameters of type UMOMessage
protected  String MuleManagerComponent.handleException(UMOMessage result, Throwable e)
          Wraps an exception into a MuleMessage with an Exception payload and returns the Xml representation of it
 

Uses of UMOMessage in org.mule.impl.internal.notifications
 

Methods in org.mule.impl.internal.notifications that return UMOMessage
protected static UMOMessage MessageNotification.cloneMessage(UMOMessage message)
           
 UMOMessage AdminNotification.getMessage()
           
 

Methods in org.mule.impl.internal.notifications with parameters of type UMOMessage
protected static UMOMessage MessageNotification.cloneMessage(UMOMessage message)
           
 

Constructors in org.mule.impl.internal.notifications with parameters of type UMOMessage
AdminNotification(UMOMessage message, int action, String resourceIdentifier)
           
MessageNotification(UMOMessage resource, UMOImmutableEndpoint endpoint, String identifier, int action)
           
 

Uses of UMOMessage in org.mule.impl.model
 

Methods in org.mule.impl.model that return UMOMessage
protected abstract  UMOMessage AbstractComponent.doSend(UMOEvent event)
           
 UMOMessage AbstractComponent.sendEvent(UMOEvent event)
           
 

Methods in org.mule.impl.model with parameters of type UMOMessage
protected  ReplyToHandler DefaultMuleProxy.getReplyToHandler(UMOMessage message, UMOImmutableEndpoint endpoint)
           
 

Uses of UMOMessage in org.mule.impl.model.direct
 

Methods in org.mule.impl.model.direct that return UMOMessage
protected  UMOMessage DirectComponent.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.impl.model.pipeline
 

Methods in org.mule.impl.model.pipeline that return UMOMessage
protected  UMOMessage PipelineComponent.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.impl.model.seda
 

Methods in org.mule.impl.model.seda that return UMOMessage
 UMOMessage SedaComponent.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.impl.model.seda.optimised
 

Methods in org.mule.impl.model.seda.optimised that return UMOMessage
protected  UMOMessage OptimisedMuleProxy.invokeUmo(UMOEventContext context)
           
 

Uses of UMOMessage in org.mule.impl.model.streaming
 

Methods in org.mule.impl.model.streaming that return UMOMessage
protected  UMOMessage StreamingComponent.doSend(UMOEvent event)
           
 

Constructors in org.mule.impl.model.streaming with parameters of type UMOMessage
StreamingException(Message message, UMOMessage umoMessage)
           
StreamingException(Message message, UMOMessage umoMessage, Throwable cause)
           
 

Uses of UMOMessage in org.mule.interceptors
 

Methods in org.mule.interceptors that return UMOMessage
 UMOMessage JXPathNormalizerInterceptor.after(Invocation invocation)
          This method is invoked after the event has been processed
abstract  UMOMessage MessageNormalizerInterceptor.after(Invocation invocation)
          This method is invoked after the event has been processed
 UMOMessage JXPathNormalizerInterceptor.before(Invocation invocation)
          This method is invoked before the event is processed
abstract  UMOMessage MessageNormalizerInterceptor.before(Invocation invocation)
          This method is invoked before the event is processed
 UMOMessage MessageNormalizerInterceptor.intercept(Invocation invocation)
           
 UMOMessage TimerInterceptor.intercept(Invocation invocation)
           
 UMOMessage InterceptorStack.intercept(Invocation invocation)
           
 UMOMessage EnvelopeInterceptor.intercept(Invocation invocation)
           
 

Uses of UMOMessage in org.mule.providers
 

Methods in org.mule.providers that return UMOMessage
protected  UMOMessage AbstractMessageReceiver.applyResponseTransformer(UMOMessage returnMessage)
           
protected abstract  UMOMessage AbstractMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected abstract  UMOMessage AbstractMessageDispatcher.doSend(UMOEvent event)
           
protected  UMOMessage AbstractMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
 UMOMessage InternalMessageListener.onMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
protected  UMOMessage AbstractReceiverWorker.postProcessMessage(UMOMessage message)
          If a result is returned back this method will get called before the message is added to te list of results (these are later passed to AbstractReceiverWorker.handleResults(java.util.List))
 UMOMessage AbstractMessageDispatcher.receive(long timeout)
          Make a specific request to the underlying transport
 UMOMessage AbstractConnector.receive(UMOEndpointURI endpointUri, long timeout)
          Make a specific request to the underlying transport
 UMOMessage AbstractConnector.receive(UMOImmutableEndpoint endpoint, long timeout)
          Make a specific request to the underlying transport
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, boolean synchronous)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, boolean synchronous, OutputStream outputStream)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, OutputStream outputStream)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
 UMOMessage AbstractMessageDispatcher.send(UMOEvent event)
           
 UMOMessage AbstractConnector.send(UMOImmutableEndpoint endpoint, UMOEvent event)
          Sends an event from the endpoint to the external system
 

Methods in org.mule.providers with parameters of type UMOMessage
protected  UMOMessage AbstractMessageReceiver.applyResponseTransformer(UMOMessage returnMessage)
           
 OutputStream AbstractConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
          Will get the output stream for this type of transport.
protected  UMOMessage AbstractMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
 UMOMessage InternalMessageListener.onMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
protected  UMOMessage AbstractReceiverWorker.postProcessMessage(UMOMessage message)
          If a result is returned back this method will get called before the message is added to te list of results (these are later passed to AbstractReceiverWorker.handleResults(java.util.List))
 void ReplyToHandler.processReplyTo(UMOEvent event, UMOMessage returnMessage, Object replyTo)
           
 void DefaultReplyToHandler.processReplyTo(UMOEvent event, UMOMessage returnMessage, Object replyTo)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, boolean synchronous)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, boolean synchronous, OutputStream outputStream)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, OutputStream outputStream)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous)
           
 UMOMessage AbstractMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
protected  void AbstractMessageReceiver.setExceptionDetails(UMOMessage message, Throwable exception)
          This method is used to set any additional aand possibly transport specific information on the return message where it has an exception payload.
 

Uses of UMOMessage in org.mule.providers.bpm
 

Methods in org.mule.providers.bpm that return UMOMessage
protected  UMOMessage ProcessMessageDispatcher.doReceive(long timeout)
           
 UMOMessage ProcessMessageDispatcher.doSend(UMOEvent event)
          Performs a synchronous action on the BPMS.
protected  UMOMessage ProcessMessageReceiver.generateEvent(String endpoint, Object payload, Map messageProperties, boolean synchronous)
           
 UMOMessage ProcessConnector.generateMessage(String endpoint, Object payloadObject, Map messageProperties, boolean synchronous)
           
 UMOMessage MessageService.generateMessage(String endpoint, Object payloadObject, Map messageProperties, boolean synchronous)
           
 UMOMessage ProcessMessageReceiver.generateSynchronousEvent(String endpoint, Object payload, Map messageProperties)
           
 

Uses of UMOMessage in org.mule.providers.bpm.jbpm
 

Methods in org.mule.providers.bpm.jbpm that return UMOMessage
 UMOMessage MuleMessageService.generateMessage(String endpoint, Object payloadObject, Map messageProperties, boolean synchronous)
           
 

Uses of UMOMessage in org.mule.providers.email
 

Methods in org.mule.providers.email that return UMOMessage
protected  UMOMessage SmtpMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage RetrieveMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport.
protected  UMOMessage SmtpMessageDispatcher.doSend(UMOEvent event)
           
protected  UMOMessage RetrieveMessageDispatcher.doSend(UMOEvent event)
           
protected  UMOMessage RetrieveMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
 

Methods in org.mule.providers.email with parameters of type UMOMessage
protected  UMOMessage RetrieveMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.email.filters
 

Methods in org.mule.providers.email.filters with parameters of type UMOMessage
 boolean AbstractMailFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.file
 

Methods in org.mule.providers.file that return UMOMessage
protected  UMOMessage FileMessageDispatcher.doReceive(long timeout)
          Will attempt to do a receive from a directory, if the endpointUri resolves to a file name the file will be returned, otherwise the first file in the directory according to the filename filter configured on the connector.
protected  UMOMessage FileMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.file with parameters of type UMOMessage
 OutputStream FileConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
          Well get the output stream (if any) for this type of transport.
 

Uses of UMOMessage in org.mule.providers.file.filters
 

Methods in org.mule.providers.file.filters with parameters of type UMOMessage
 boolean FilenameWildcardFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.ftp
 

Methods in org.mule.providers.ftp that return UMOMessage
protected  UMOMessage FtpMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage FtpMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.ftp with parameters of type UMOMessage
 OutputStream FtpConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
          Well get the output stream (if any) for this type of transport.
 

Uses of UMOMessage in org.mule.providers.http
 

Methods in org.mule.providers.http that return UMOMessage
protected  UMOMessage HttpClientMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage HttpClientMessageDispatcher.doSend(UMOEvent event)
           
protected  UMOMessage HttpMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
 

Methods in org.mule.providers.http with parameters of type UMOMessage
protected  HttpResponse HttpMessageReceiver.HttpWorker.buildFailureResponse(RequestLine requestLine, UMOMessage message)
           
protected  String HttpMessageReceiver.getRequestPath(UMOMessage message)
           
protected  UMOMessageReceiver HttpMessageReceiver.getTargetReceiver(UMOMessage message, UMOEndpoint endpoint)
           
protected  UMOMessage HttpMessageReceiver.handleUnacceptedFilter(UMOMessage message)
           
protected  void HttpMessageReceiver.HttpWorker.preRouteMessage(UMOMessage message)
           
 void HttpSessionHandler.retrieveSessionInfoFromMessage(UMOMessage message, UMOSession session)
           
 void HttpSessionHandler.storeSessionInfoToMessage(UMOSession session, UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.http.servlet
 

Methods in org.mule.providers.http.servlet with parameters of type UMOMessage
protected  void AbstractReceiverServlet.writeResponse(HttpServletResponse servletResponse, UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.jbi
 

Methods in org.mule.providers.jbi that return UMOMessage
static UMOMessage JbiUtils.createMessage(javax.jbi.messaging.NormalizedMessage message)
           
protected  UMOMessage JbiMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage JbiMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.jbi with parameters of type UMOMessage
static void JbiUtils.populateNormalizedMessage(UMOMessage muleMessage, javax.jbi.messaging.NormalizedMessage message)
           
 

Uses of UMOMessage in org.mule.providers.jbi.components
 

Methods in org.mule.providers.jbi.components that return UMOMessage
 UMOMessage MuleReceiver.onMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
 

Methods in org.mule.providers.jbi.components with parameters of type UMOMessage
 UMOMessage MuleReceiver.onMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
 

Uses of UMOMessage in org.mule.providers.jdbc
 

Methods in org.mule.providers.jdbc that return UMOMessage
protected  UMOMessage JdbcMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage JdbcMessageDispatcher.doReceive(long timeout, UMOEvent event)
          Make a specific request to the underlying transport Special case: The event is need when doReceive was called from doSend
protected  UMOMessage JdbcMessageDispatcher.doSend(UMOEvent event)
           
protected  UMOMessage JdbcMessageDispatcher.executeWriteStatement(UMOEvent event, String writeStmt)
           
 

Uses of UMOMessage in org.mule.providers.jms
 

Methods in org.mule.providers.jms that return UMOMessage
protected  UMOMessage JmsMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage JmsMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.jms with parameters of type UMOMessage
 void JmsReplyToHandler.processReplyTo(UMOEvent event, UMOMessage returnMessage, Object replyTo)
           
 

Uses of UMOMessage in org.mule.providers.jms.filters
 

Methods in org.mule.providers.jms.filters with parameters of type UMOMessage
 boolean JmsSelectorFilter.accept(UMOMessage message)
           
 boolean JmsPropertyFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.jms.transformers
 

Methods in org.mule.providers.jms.transformers with parameters of type UMOMessage
protected  void AbstractJmsTransformer.setJmsProperties(UMOMessage umoMessage, Message msg)
           
 

Uses of UMOMessage in org.mule.providers.oracle.jms
 

Methods in org.mule.providers.oracle.jms that return UMOMessage
protected  UMOMessage OracleJmsMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport Save a copy of the endpoint's properties within the OracleJmsSupport object.
 

Uses of UMOMessage in org.mule.providers.quartz
 

Methods in org.mule.providers.quartz that return UMOMessage
protected  UMOMessage QuartzMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage QuartzMessageDispatcher.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.providers.rmi
 

Methods in org.mule.providers.rmi that return UMOMessage
protected  UMOMessage RmiMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
 UMOMessage RmiMessageDispatcher.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.providers.soap.axis
 

Methods in org.mule.providers.soap.axis that return UMOMessage
protected  UMOMessage AxisMessageDispatcher.createMessage(Object result, org.apache.axis.client.Call call)
           
protected  UMOMessage AxisMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage AxisMessageDispatcher.doSend(UMOEvent event)
           
 UMOMessage AxisMessageDispatcher.receive(String endpoint, Object[] args)
           
 UMOMessage AxisMessageDispatcher.receive(String endpoint, javax.xml.soap.SOAPEnvelope envelope)
           
 

Methods in org.mule.providers.soap.axis with parameters of type UMOMessage
protected  void AxisMessageDispatcher.setMessageContextAttachments(UMOMessage message, org.apache.axis.MessageContext ctx)
           
protected  void AxisMessageDispatcher.setMessageContextProperties(UMOMessage message, org.apache.axis.MessageContext ctx)
           
 

Uses of UMOMessage in org.mule.providers.soap.xfire
 

Methods in org.mule.providers.soap.xfire that return UMOMessage
protected  UMOMessage XFireMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage XFireMessageDispatcher.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.providers.stream
 

Methods in org.mule.providers.stream that return UMOMessage
protected  UMOMessage StreamMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage StreamMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.stream with parameters of type UMOMessage
 OutputStream SystemStreamConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.tcp
 

Methods in org.mule.providers.tcp that return UMOMessage
protected  UMOMessage TcpMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage TcpMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.providers.tcp with parameters of type UMOMessage
 OutputStream TcpConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.udp
 

Methods in org.mule.providers.udp that return UMOMessage
protected  UMOMessage UdpMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage UdpMessageDispatcher.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.providers.vm
 

Methods in org.mule.providers.vm that return UMOMessage
protected  UMOMessage VMMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage VMMessageDispatcher.doSend(UMOEvent event)
           
 

Constructors in org.mule.providers.vm with parameters of type UMOMessage
VMMessageAdapter(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.providers.xmpp
 

Methods in org.mule.providers.xmpp that return UMOMessage
protected  UMOMessage XmppMessageDispatcher.doReceive(long timeout)
          Make a specific request to the underlying transport
protected  UMOMessage XmppMessageDispatcher.doSend(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.providers.xmpp.filters
 

Methods in org.mule.providers.xmpp.filters with parameters of type UMOMessage
 boolean AbstractXmppFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.ra
 

Methods in org.mule.ra that return UMOMessage
protected  UMOMessage JcaComponent.doSend(UMOEvent event)
          Implementation of template method which is never call because send() is overwritten
 UMOMessage DefaultMuleConnection.receive(String url, long timeout)
          Will receive an event from an endpointUri determined by the url
 UMOMessage MuleConnection.receive(String url, long timeout)
           
 UMOMessage DefaultMuleConnection.send(String url, Object payload, Map messageProperties)
          Sends an object (payload) synchronous to the given url and returns a UMOMessage response back.
 UMOMessage MuleConnection.send(String url, Object payload, Map messageProperties)
           
 UMOMessage JcaComponent.sendEvent(UMOEvent event)
          This is the synchronous call method and not supported by components managed in a JCA container
 

Methods in org.mule.ra with parameters of type UMOMessage
protected  UMOEvent DefaultMuleConnection.getEvent(UMOMessage message, UMOEndpointURI uri, boolean synchronous)
          Packages a mule event for the current request
 

Uses of UMOMessage in org.mule.routing
 

Methods in org.mule.routing that return UMOMessage
 UMOMessage LoggingCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ForwardingCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ComponentCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 

Methods in org.mule.routing with parameters of type UMOMessage
 UMOMessage LoggingCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ForwardingCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ComponentCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 String CorrelationPropertiesExtractor.getCorrelationId(UMOMessage message)
           
 String CorrelationPropertiesExtractor.getMessageId(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.routing.filters
 

Methods in org.mule.routing.filters with parameters of type UMOMessage
 boolean OGNLFilter.accept(UMOMessage message)
           
 boolean WildcardFilter.accept(UMOMessage message)
           
 boolean EqualsFilter.accept(UMOMessage message)
           
 boolean PayloadTypeFilter.accept(UMOMessage message)
           
 boolean RegExFilter.accept(UMOMessage message)
           
 boolean ExceptionTypeFilter.accept(UMOMessage message)
          Check a given message against this filter.
 boolean MessagePropertyFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.routing.filters.logic
 

Methods in org.mule.routing.filters.logic with parameters of type UMOMessage
 boolean OrFilter.accept(UMOMessage message)
           
 boolean AndFilter.accept(UMOMessage message)
           
 boolean NotFilter.accept(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.routing.filters.xml
 

Methods in org.mule.routing.filters.xml with parameters of type UMOMessage
 boolean IsXmlFilter.accept(UMOMessage obj)
           
 boolean JXPathFilter.accept(UMOMessage obj)
           
 

Uses of UMOMessage in org.mule.routing.inbound
 

Methods in org.mule.routing.inbound that return UMOMessage
protected  UMOMessage MessageChunkingAggregator.aggregateEvents(EventGroup events)
          This method is invoked if the shouldAggregate method is called and returns true.
protected abstract  UMOMessage AbstractEventAggregator.aggregateEvents(EventGroup events)
          This method is invoked if the shouldAggregate method is called and returns true.
 UMOMessage InboundRouterCollection.route(UMOEvent event)
           
 UMOMessage InboundRouterCollection.send(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.routing.nested
 

Methods in org.mule.routing.nested that return UMOMessage
 UMOMessage NestedRouter.route(UMOEvent event)
           
 

Uses of UMOMessage in org.mule.routing.outbound
 

Methods in org.mule.routing.outbound that return UMOMessage
protected  UMOMessage OutboundRouterCollection.catchAll(UMOMessage message, UMOSession session, boolean synchronous)
           
protected  UMOMessage FilteringXmlMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
          Retrieves a specific message part for the given endpoint.
protected  UMOMessage FilteringListMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
           
protected abstract  UMOMessage AbstractMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
          Retrieves a specific message part for the given endpoint.
 UMOMessage RoundRobinXmlSplitter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage MessageChunkingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ChainingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage OutboundRouterCollection.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage TemplateEndpointRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage FilteringOutboundRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage OutboundPassThroughRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractRecipientList.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ExceptionBasedRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage TransformerRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage EndpointSelector.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage MulticastingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractMessageSplitter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractOutboundRouter.send(UMOSession session, UMOMessage message, UMOEndpoint endpoint)
           
 

Methods in org.mule.routing.outbound with parameters of type UMOMessage
protected  UMOMessage OutboundRouterCollection.catchAll(UMOMessage message, UMOSession session, boolean synchronous)
           
 void AbstractOutboundRouter.dispatch(UMOSession session, UMOMessage message, UMOEndpoint endpoint)
           
protected  boolean ExceptionBasedRouter.exceptionPayloadAvailable(UMOMessage message)
           
 UMOEndpoint FilteringOutboundRouter.getEndpoint(int index, UMOMessage message)
          Will Return the endpont at the given index and will resolve any template tags on the Endpoint URI if necessary
protected  UMOEndpoint RoundRobinXmlSplitter.getEndpointForMessage(UMOMessage message)
          Retrieves a specific message part for the given endpoint.
 UMOEndpoint[] OutboundRouterCollection.getEndpointsForMessage(UMOMessage message)
          A helper method for finding out which endpoints a message would be routed to without actually routing the the message
protected  UMOMessage FilteringXmlMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
          Retrieves a specific message part for the given endpoint.
protected  UMOMessage FilteringListMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
           
protected abstract  UMOMessage AbstractMessageSplitter.getMessagePart(UMOMessage message, UMOEndpoint endpoint)
          Retrieves a specific message part for the given endpoint.
protected  UMOEndpoint AbstractRecipientList.getRecipientEndpoint(UMOMessage message, String recipient)
           
protected abstract  List AbstractRecipientList.getRecipients(UMOMessage message)
           
protected  List StaticRecipientList.getRecipients(UMOMessage message)
           
protected  void FilteringXmlMessageSplitter.initialise(UMOMessage message)
          Template method can be used to split the message up before the getMessagePart method is called .
protected  void FilteringListMessageSplitter.initialise(UMOMessage message)
          Template method can be used to split the message up before the getMessagePart method is called .
protected  void AbstractMessageSplitter.initialise(UMOMessage message)
          This method can be implemented to split the message up before AbstractMessageSplitter.getMessagePart(UMOMessage, UMOEndpoint) method is called.
 boolean FilteringOutboundRouter.isMatch(UMOMessage message)
           
 boolean TransformerRouter.isMatch(UMOMessage message)
           
protected  void ChainingRouter.processIntermediaryResult(UMOMessage localResult, UMOMessage intermediaryResult)
          Process intermediary result of invocation.
 UMOMessage RoundRobinXmlSplitter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage MessageChunkingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ChainingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage OutboundRouterCollection.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage TemplateEndpointRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage FilteringOutboundRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage OutboundPassThroughRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractRecipientList.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage ExceptionBasedRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage TransformerRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage EndpointSelector.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage MulticastingRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractMessageSplitter.route(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage AbstractOutboundRouter.send(UMOSession session, UMOMessage message, UMOEndpoint endpoint)
           
protected  void AbstractOutboundRouter.setMessageProperties(UMOSession session, UMOMessage message, UMOEndpoint endpoint)
           
 

Uses of UMOMessage in org.mule.routing.response
 

Methods in org.mule.routing.response that return UMOMessage
protected  UMOMessage SingleResponseRouter.aggregateEvents(EventGroup events)
          The SingleResponseRouter will always return the first event of an event group.
protected abstract  UMOMessage AbstractResponseAggregator.aggregateEvents(EventGroup events)
           
 UMOMessage AbstractResponseAggregator.getResponse(UMOMessage message)
          This method is called by the responding callee thread and should return the aggregated response message
 UMOMessage ResponseRouterCollection.getResponse(UMOMessage message)
           
 

Methods in org.mule.routing.response with parameters of type UMOMessage
protected  Object AbstractResponseRouter.getCallResponseAggregateIdentifier(UMOMessage message)
          Extracts a Group identifier from the current event.
protected  Object AbstractResponseRouter.getReplyAggregateIdentifier(UMOMessage message)
          Extracts a 'Correlation Id' from a reply message.
 UMOMessage AbstractResponseAggregator.getResponse(UMOMessage message)
          This method is called by the responding callee thread and should return the aggregated response message
 UMOMessage ResponseRouterCollection.getResponse(UMOMessage message)
           
 

Uses of UMOMessage in org.mule.samples.voipservice.routers
 

Methods in org.mule.samples.voipservice.routers that return UMOMessage
protected  UMOMessage PaymentValidationResponseAggregator.aggregateEvents(EventGroup events)
           
 

Uses of UMOMessage in org.mule.samples.voipservice.service
 

Methods in org.mule.samples.voipservice.service that return UMOMessage
 UMOMessage SyncVoipBroker.validate(ServiceParamTO serviceParamTO)
           
 

Uses of UMOMessage in org.mule.tck.testmodels.mule
 

Methods in org.mule.tck.testmodels.mule that return UMOMessage
protected  UMOMessage TestResponseAggregator.aggregateEvents(EventGroup events)
          This method is invoked if the shouldAggregate method is called and returns true.
 UMOMessage TestCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage TestMessageDispatcher.doReceive(long timeout)
           
protected  UMOMessage TestMessageDispatcher.doSend(UMOEvent event)
           
 

Methods in org.mule.tck.testmodels.mule with parameters of type UMOMessage
 UMOMessage TestCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 

Uses of UMOMessage in org.mule.umo
 

Fields in org.mule.umo declared as UMOMessage
protected  UMOMessage MessagingException.umoMessage
          The UMOMessage being processed when the error occurred
 

Methods in org.mule.umo that return UMOMessage
 UMOMessage Invocation.execute()
          Excutes this invocation
 UMOMessage UMOEventContext.getMessage()
          Returns the message payload for this event
 UMOMessage FutureMessageResult.getMessage()
           
 UMOMessage Invocation.getMessage()
          Returns the current message
 UMOMessage UMOEvent.getMessage()
          Returns the message payload for this event
 UMOMessage FutureMessageResult.getMessage(long timeout)
           
 UMOMessage MessagingException.getUmoMessage()
           
 UMOMessage UMOInterceptor.intercept(Invocation invocation)
          Invoked by the previous interceptor in the chain
 UMOMessage UMOEventContext.receiveEvent(String endpointName, long timeout)
          Requests a synchronous receive of an event on the component.
 UMOMessage UMOSession.receiveEvent(String endpointName, long timeout)
          Requests a synchronous receive of an event on the component
 UMOMessage UMOEventContext.receiveEvent(UMOEndpoint endpoint, long timeout)
          Requests a synchronous receive of an event on the component.
 UMOMessage UMOEventContext.receiveEvent(UMOEndpointURI endpoint, long timeout)
          Requests a synchronous receive of an event on the component.
 UMOMessage UMOSession.receiveEvent(UMOImmutableEndpoint endpoint, long timeout)
          Requests a synchronous receive of an event on the component
 UMOMessage UMOEventContext.sendEvent(Object message)
          This will send an event via the configured outbound router on the component
 UMOMessage UMOSession.sendEvent(UMOEvent event)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOComponent.sendEvent(UMOEvent event)
          Makes a synhronous event call to the component.
 UMOMessage UMOEventContext.sendEvent(UMOMessage message)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message)
          This will send an event via the configured outbound endpoint on the component for this session
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, UMOEndpointURI endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 

Methods in org.mule.umo with parameters of type UMOMessage
 boolean UMOFilter.accept(UMOMessage message)
          Check a given message against this filter.
 UMOEvent UMOSession.createOutboundEvent(UMOMessage message, UMOImmutableEndpoint endpoint, UMOEvent previousEvent)
          Creates an outbound event for this session
 void UMOEventContext.dispatchEvent(UMOMessage message)
          This will dispatch an event asynchronously via the configured outbound endpoint on the component for this session
 void UMOSession.dispatchEvent(UMOMessage message)
          This will dispatch an event asynchronously via the configured outbound endpoint on the component for this session
 void UMOEventContext.dispatchEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event.
 void UMOSession.dispatchEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 void UMOEventContext.dispatchEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 void UMOEventContext.dispatchEvent(UMOMessage message, UMOEndpointURI endpoint)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 void UMOSession.dispatchEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
          Depending on the session state this methods either Passes an event asynchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOEventContext.sendEvent(UMOMessage message)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message)
          This will send an event via the configured outbound endpoint on the component for this session
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message, String endpointName)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, UMOEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOEventContext.sendEvent(UMOMessage message, UMOEndpointURI endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 UMOMessage UMOSession.sendEvent(UMOMessage message, UMOImmutableEndpoint endpoint)
          Depending on the session state this methods either Passes an event synchronously to the next available Mule UMO in the pool or via the endpoint configured for the event
 FutureMessageResult UMOEventContext.sendEventAsync(UMOMessage message, int timeout)
          sends an event request via the configured outbound router for this component.
 FutureMessageResult UMOEventContext.sendEventAsync(UMOMessage message, String endpointName, int timeout)
          sends an event request via the configured outbound router for this component.
 FutureMessageResult UMOEventContext.sendEventAsync(UMOMessage message, UMOEndpointURI endpoint, int timeout)
          sends an event request via the configured outbound router for this component.
 void Invocation.setMessage(UMOMessage message)
           
 

Constructors in org.mule.umo with parameters of type UMOMessage
ComponentException(Message message, UMOMessage umoMessage, UMOComponent component)
           
ComponentException(Message message, UMOMessage umoMessage, UMOComponent component, Throwable cause)
           
ComponentException(UMOMessage umoMessage, UMOComponent component, Throwable cause)
           
Invocation(UMOImmutableDescriptor descriptor, UMOMessage message, Invocation invocation)
          Constructs an initialised invocation
MessagingException(Message message, UMOMessage umoMessage)
           
MessagingException(Message message, UMOMessage umoMessage, Throwable cause)
           
 

Uses of UMOMessage in org.mule.umo.provider
 

Methods in org.mule.umo.provider that return UMOMessage
 UMOMessage UMOMessageDispatching.receive(long timeout)
          Make a specific request to the underlying transport
 UMOMessage UMOConnector.receive(UMOEndpointURI endpointUri, long timeout)
          Deprecated. Use receive(UMOImmutableEndpoint endpoint, long timeout)
 UMOMessage UMOConnector.receive(UMOImmutableEndpoint endpoint, long timeout)
          Make a specific request to the underlying transport
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, boolean synchronous)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, boolean synchronous, OutputStream outputStream)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, OutputStream outputStream)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
 UMOMessage UMOMessageDispatching.send(UMOEvent event)
          Sends an event from the endpoint to the external system
 UMOMessage UMOConnector.send(UMOImmutableEndpoint endpoint, UMOEvent event)
          Sends an event from the endpoint to the external system
 

Methods in org.mule.umo.provider with parameters of type UMOMessage
 OutputStream UMOConnector.getOutputStream(UMOImmutableEndpoint endpoint, UMOMessage message)
          Will get the output stream for this type of transport.
 void UMOSessionHandler.retrieveSessionInfoFromMessage(UMOMessage message, UMOSession session)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, boolean synchronous)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, boolean synchronous, OutputStream outputStream)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, OutputStream outputStream)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous)
           
 UMOMessage UMOMessageReceiver.routeMessage(UMOMessage message, UMOTransaction trans, boolean synchronous, OutputStream outputStream)
           
 void UMOSessionHandler.storeSessionInfoToMessage(UMOSession session, UMOMessage message)
           
 

Constructors in org.mule.umo.provider with parameters of type UMOMessage
DispatchException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint)
           
DispatchException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint, Throwable cause)
           
DispatchException(UMOMessage message, UMOImmutableEndpoint endpoint)
           
DispatchException(UMOMessage umoMessage, UMOImmutableEndpoint endpoint, Throwable cause)
           
 

Uses of UMOMessage in org.mule.umo.routing
 

Methods in org.mule.umo.routing that return UMOMessage
 UMOMessage UMORouterCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOMessage UMOResponseRouterCollection.getResponse(UMOMessage message)
           
 UMOMessage UMOResponseRouter.getResponse(UMOMessage message)
          Called by the Mule framework once the outbound router has been processed on a component the Message passed in is the response message from the component (or outbount router if a response was returned).
 UMOMessage UMOInboundRouterCollection.route(UMOEvent event)
           
 UMOMessage UMONestedRouter.route(UMOEvent event)
           
 UMOMessage UMOOutboundRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
          This method is responsible for routing the Message via the Session.
 UMOMessage UMOOutboundRouterCollection.route(UMOMessage message, UMOSession session, boolean synchronous)
          Prepares one or more events to be dispached by a Message Dispatcher.
 

Methods in org.mule.umo.routing with parameters of type UMOMessage
 UMOMessage UMORouterCatchAllStrategy.catchMessage(UMOMessage message, UMOSession session, boolean synchronous)
           
 UMOEndpoint[] UMOOutboundRouterCollection.getEndpointsForMessage(UMOMessage message)
          A helper method for finding out which endpoints a message would be routed to without actually routing the the message.
 UMOMessage UMOResponseRouterCollection.getResponse(UMOMessage message)
           
 UMOMessage UMOResponseRouter.getResponse(UMOMessage message)
          Called by the Mule framework once the outbound router has been processed on a component the Message passed in is the response message from the component (or outbount router if a response was returned).
 boolean UMOOutboundRouter.isMatch(UMOMessage message)
          Determines if the event should be processed by this router.
 UMOMessage UMOOutboundRouter.route(UMOMessage message, UMOSession session, boolean synchronous)
          This method is responsible for routing the Message via the Session.
 UMOMessage UMOOutboundRouterCollection.route(UMOMessage message, UMOSession session, boolean synchronous)
          Prepares one or more events to be dispached by a Message Dispatcher.
 

Constructors in org.mule.umo.routing with parameters of type UMOMessage
ComponentRoutingException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint, UMOComponent component)
           
ComponentRoutingException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint, UMOComponent component, Throwable cause)
           
ComponentRoutingException(UMOMessage umoMessage, UMOImmutableEndpoint endpoint, UMOComponent component)
           
ComponentRoutingException(UMOMessage umoMessage, UMOImmutableEndpoint endpoint, UMOComponent component, Throwable cause)
           
CouldNotRouteInboundEventException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint)
           
CouldNotRouteInboundEventException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
CouldNotRouteInboundEventException(UMOMessage message, UMOEndpoint endpoint)
           
CouldNotRouteInboundEventException(UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
CouldNotRouteOutboundMessageException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint)
           
CouldNotRouteOutboundMessageException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
CouldNotRouteOutboundMessageException(UMOMessage message, UMOEndpoint endpoint)
           
CouldNotRouteOutboundMessageException(UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
ResponseTimeoutException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint)
           
ResponseTimeoutException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
RoutePathNotFoundException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint)
           
RoutePathNotFoundException(Message message, UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
RoutePathNotFoundException(UMOMessage message, UMOEndpoint endpoint)
           
RoutePathNotFoundException(UMOMessage umoMessage, UMOEndpoint endpoint, Throwable cause)
           
RoutingException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint)
           
RoutingException(Message message, UMOMessage umoMessage, UMOImmutableEndpoint endpoint, Throwable cause)
           
RoutingException(UMOMessage message, UMOImmutableEndpoint endpoint)
           
RoutingException(UMOMessage umoMessage, UMOImmutableEndpoint endpoint, Throwable cause)
           
 

Uses of UMOMessage in org.mule.umo.security
 

Constructors in org.mule.umo.security with parameters of type UMOMessage
CredentialsNotSetException(Message message, UMOMessage umoMessage)
           
CredentialsNotSetException(Message message, UMOMessage umoMessage, Throwable cause)
           
CredentialsNotSetException(UMOMessage umoMessage, UMOSecurityContext context, UMOImmutableEndpoint endpoint, UMOEndpointSecurityFilter filter)
           
EncryptionNotSupportedException(Message message, UMOMessage umoMessage)
           
EncryptionNotSupportedException(Message message, UMOMessage umoMessage, Throwable cause)
           
SecurityException(Message message, UMOMessage umoMessage)
           
SecurityException(Message message, UMOMessage umoMessage, Throwable cause)
           
UnauthorisedException(Message message, UMOMessage umoMessage)
           
UnauthorisedException(Message message, UMOMessage umoMessage, Throwable cause)
           
UnauthorisedException(UMOMessage umoMessage, UMOSecurityContext context, UMOImmutableEndpoint endpoint, UMOEndpointSecurityFilter filter)
           
UnsupportedAuthenticationSchemeException(Message message, UMOMessage umoMessage)
           
UnsupportedAuthenticationSchemeException(Message message, UMOMessage umoMessage, Throwable cause)
           
 



Copyright © 2003-2008 MuleSource, Inc.. All Rights Reserved.