Uses of Interface
org.mule.api.processor.MessageProcessor

Packages that use MessageProcessor
org.mule.api The Universal Message Object(tm) API provides a way for components to interact without needing to know about the protocol or delivery mechanisms of information passed between them 
org.mule.api.cache   
org.mule.api.component   
org.mule.api.construct   
org.mule.api.endpoint Endpoint interfaces. 
org.mule.api.interceptor   
org.mule.api.processor   
org.mule.api.routing Interfaces that define inbound and outbound routing API. 
org.mule.api.service   
org.mule.api.source   
org.mule.api.transformer Contains the interfaces for transformers and exceptions for the Transformer API. 
org.mule.api.transport Contains the interfaces that comprise a provider implementation. 
org.mule.component   
org.mule.component.simple A collection of simple mule components that can be useful to simplify configuration while testing. 
org.mule.config.dsl.routers   
org.mule.config.i18n Internationalisation support for Mule messages and exception messages. 
org.mule.config.spring.factories   
org.mule.config.transformer   
org.mule.construct   
org.mule.construct.builder   
org.mule.construct.processor   
org.mule.context.notification Internal server notification types fired via the MuleManager. 
org.mule.el   
org.mule.endpoint Implemtation of Mule endpoint uris. 
org.mule.endpoint.inbound   
org.mule.endpoint.outbound   
org.mule.enricher   
org.mule.example.bookstore.transformers   
org.mule.example.errorhandler   
org.mule.example.geomail.transformers   
org.mule.example.hello   
org.mule.example.loanbroker.processor   
org.mule.example.loanbroker.routers   
org.mule.example.loanbroker.transformers   
org.mule.example.scripting   
org.mule.exception   
org.mule.execution   
org.mule.expression   
org.mule.expression.transformers   
org.mule.interceptor   
org.mule.lifecycle.processor   
org.mule.model.seda   
org.mule.module.atom   
org.mule.module.atom.routing   
org.mule.module.atom.transformers   
org.mule.module.bpm   
org.mule.module.cxf   
org.mule.module.cxf.component   
org.mule.module.cxf.config   
org.mule.module.ibeans.config   
org.mule.module.ibeans.spi.support   
org.mule.module.jca 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.module.jersey   
org.mule.module.json.transformers Transfromers for converting from JavaBeans and collections to JSON and back again. 
org.mule.module.rss.transformers   
org.mule.module.scripting.component Base classes for script based components such as BeanShell or Groovy. 
org.mule.module.scripting.filter   
org.mule.module.scripting.transformer   
org.mule.module.spring.remoting   
org.mule.module.sxc   
org.mule.module.ws.config.spring.factories   
org.mule.module.ws.construct   
org.mule.module.xml.routing   
org.mule.module.xml.transformer Xml and Xslt Transformer implementations. 
org.mule.module.xml.transformer.jaxb   
org.mule.processor   
org.mule.processor.chain   
org.mule.processor.strategy   
org.mule.routing Defines the core routing patterns supported by mule. 
org.mule.routing.correlation   
org.mule.routing.outbound Outbound router implementation as described in the Enterprise Integration Patterns book. 
org.mule.routing.requestreply   
org.mule.service   
org.mule.service.processor   
org.mule.source   
org.mule.tck.functional Helper classes and interfaces used by Mule fnctional tests. 
org.mule.tck.transformer   
org.mule.transformer Provides the default transformer base implementations for Mule including compression and encryption support. 
org.mule.transformer.codec Transformers for Base64, UC and UU encoding/decoding. 
org.mule.transformer.compression Transformers for compressing and uncompressing message payloads. 
org.mule.transformer.encryption Transformers for encrypting and decrypting message payloads. 
org.mule.transformer.simple Basic transformer implementations. 
org.mule.transport Contains Abstract classes providing common functionality for all Mule providers. 
org.mule.transport.ajax   
org.mule.transport.ejb   
org.mule.transport.email Provides pop3, smtp and imap connectivity for Mule
org.mule.transport.email.transformers Contains transformers to convert to and from the java.mail.Message type. 
org.mule.transport.file Provides file transport in the form of a directory listeners and file dispatchers. 
org.mule.transport.file.transformers Transformers for converting to and from the FileMessage type. 
org.mule.transport.ftp   
org.mule.transport.http Provides http transport including proxy support. 
org.mule.transport.http.components   
org.mule.transport.http.config.spring.factories   
org.mule.transport.http.construct   
org.mule.transport.http.servlet   
org.mule.transport.http.transformers   
org.mule.transport.jdbc Provides jdbc transport. 
org.mule.transport.jms Provides Jms transport connectivity with support for all Jms features. 
org.mule.transport.jms.transformers Contains transformers to convert to and from different javax.jms.Message types 
org.mule.transport.polling   
org.mule.transport.quartz   
org.mule.transport.rmi   
org.mule.transport.servlet.transformers   
org.mule.transport.sftp   
org.mule.transport.sftp.transformers   
org.mule.transport.soap.axis Provides an Axis soap transport for Mule
org.mule.transport.soap.axis.wsdl   
org.mule.transport.stdio   
org.mule.transport.tcp Provides tcp connectivity for Mule
org.mule.transport.udp Provides Udp connectivity for Mule
org.mule.transport.vm A connector implementation allowing events to be passed between Mule sessions via in-memory queues. 
org.mule.transport.xmpp   
org.mule.transport.xmpp.transformers   
 

Uses of MessageProcessor in org.mule.api
 

Methods in org.mule.api that return MessageProcessor
 MessageProcessor MessagingException.getFailingMessageProcessor()
           
 MessageProcessor MessageProcessorAnnotationParser.parseMessageProcessor(Annotation annotation)
          Will create a Mule Router according to the annotation.
 

Constructors in org.mule.api with parameters of type MessageProcessor
MessagingException(Message message, MuleEvent event, MessageProcessor failingMessageProcessor)
           
MessagingException(Message message, MuleEvent event, Throwable cause, MessageProcessor failingMessageProcessor)
           
MessagingException(MuleEvent event, Throwable cause, MessageProcessor failingMessageProcessor)
           
 

Uses of MessageProcessor in org.mule.api.cache
 

Methods in org.mule.api.cache with parameters of type MessageProcessor
 MuleEvent CachingStrategy.process(MuleEvent request, MessageProcessor messageProcessor)
          Processes a MuleEvent using a caching schema.
 

Uses of MessageProcessor in org.mule.api.component
 

Subinterfaces of MessageProcessor in org.mule.api.component
 interface Component
          A Component component processes a MuleEvent by invoking the component instance that has been configured, optionally returning a result.
 interface InterfaceBinding
           
 interface JavaComponent
          JavaComponent is a Java Component implementation used to invoke Java component implementations.
 

Uses of MessageProcessor in org.mule.api.construct
 

Methods in org.mule.api.construct that return types with arguments of type MessageProcessor
 List<MessageProcessor> Pipeline.getMessageProcessors()
           
 

Method parameters in org.mule.api.construct with type arguments of type MessageProcessor
 void Pipeline.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 

Uses of MessageProcessor in org.mule.api.endpoint
 

Subinterfaces of MessageProcessor in org.mule.api.endpoint
 interface OutboundEndpoint
           
 

Methods in org.mule.api.endpoint that return MessageProcessor
 MessageProcessor EndpointMessageProcessorChainFactory.createInboundMessageProcessorChain(InboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 MessageProcessor EndpointMessageProcessorChainFactory.createOutboundMessageProcessorChain(OutboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 

Methods in org.mule.api.endpoint that return types with arguments of type MessageProcessor
 List<MessageProcessor> ImmutableEndpoint.getMessageProcessors()
           
 List<MessageProcessor> ImmutableEndpoint.getResponseMessageProcessors()
           
 

Methods in org.mule.api.endpoint with parameters of type MessageProcessor
 void EndpointBuilder.addMessageProcessor(MessageProcessor messageProcessor)
           
 void EndpointBuilder.addResponseMessageProcessor(MessageProcessor responseMessageProcessor)
           
 MessageProcessor EndpointMessageProcessorChainFactory.createInboundMessageProcessorChain(InboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 MessageProcessor EndpointMessageProcessorChainFactory.createOutboundMessageProcessorChain(OutboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 

Method parameters in org.mule.api.endpoint with type arguments of type MessageProcessor
 void EndpointBuilder.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 void EndpointBuilder.setResponseMessageProcessors(List<MessageProcessor> responseMessageProcessors)
           
 

Uses of MessageProcessor in org.mule.api.interceptor
 

Subinterfaces of MessageProcessor in org.mule.api.interceptor
 interface Interceptor
          Interceptor is based on a similar concept of servlet filters and works much the same way.
 

Uses of MessageProcessor in org.mule.api.processor
 

Subinterfaces of MessageProcessor in org.mule.api.processor
 interface InterceptingMessageProcessor
           Processes MuleEvent's intercepting another listener MessageProcessor.
 interface MessageProcessorChain
           
 interface MessageRouter
          A MessageProcessor that routes messages to zero or more destination message processors.
 interface RequestReplyReplierMessageProcessor
           Processes a MuleEvent's by invoking the next MessageProcessor and then rather than returning the result to this processors MessageSource sending it via a seperate reply MessageProcessor,
 

Classes in org.mule.api.processor that implement MessageProcessor
 class LoggerMessageProcessor
          MessageProcessor implementation that logs the current element of a value evaluated from it using an expression evaluator.
 

Methods in org.mule.api.processor that return MessageProcessor
 MessageProcessor MessageProcessorBuilder.build()
           
static MessageProcessor MessageProcessors.lifecyleAwareMessageProcessorWrapper(MessageProcessor mp)
           
 

Methods in org.mule.api.processor that return types with arguments of type MessageProcessor
 List<MessageProcessor> MessageProcessorChain.getMessageProcessors()
           
 

Methods in org.mule.api.processor with parameters of type MessageProcessor
 void MessageRouter.addRoute(MessageProcessor processor)
          Adds a new message processor to the list of routes
 MessageProcessorChainBuilder MessageProcessorChainBuilder.chain(MessageProcessor... processors)
           
static MessageProcessor MessageProcessors.lifecyleAwareMessageProcessorWrapper(MessageProcessor mp)
           
 void MessageRouter.removeRoute(MessageProcessor processor)
          Removes a message processor from the list of routes
 void RequestReplyReplierMessageProcessor.setReplyProcessor(MessageProcessor replyMessageProcessor)
           
static MessageProcessorChain MessageProcessors.singletonChain(MessageProcessor mp)
           
 

Method parameters in org.mule.api.processor with type arguments of type MessageProcessor
 void ProcessingStrategy.configureProcessors(List<MessageProcessor> processors, ProcessingStrategy.StageNameSource nameSource, MessageProcessorChainBuilder chainBuilder, MuleContext muleContext)
           
 

Uses of MessageProcessor in org.mule.api.routing
 

Subinterfaces of MessageProcessor in org.mule.api.routing
 interface MatchableMessageProcessor
           
 interface MatchableMessageRouter
           
 interface MatchingRouter
          Routes the message to zero or more MatchableMessageProcessors.
 interface OutboundRouter
          OutboundRouter is used to control outbound routing behaviour for an event.
 interface OutboundRouterCatchAllStrategy
          RouterCatchAllStrategy is a strategy interface that allows developers to hook in custom code when an event is being routed on the inbound or outbound but does not match any of the criteria defined for the routing.
 interface OutboundRouterCollection
          RouterCollection defines the interface for a MessageRouter that manages more than one router.
 interface SelectiveRouter
          Routes the event to MessageProcessors using a Filter to evaluate the event being processed and determine if a given route should be used.
 

Fields in org.mule.api.routing declared as MessageProcessor
protected  MessageProcessor RoutingException.route
           
 

Methods in org.mule.api.routing that return MessageProcessor
 MessageProcessor RoutingException.getRoute()
           
 

Methods in org.mule.api.routing that return types with arguments of type MessageProcessor
 List<MessageProcessor> OutboundRouter.getRoutes()
          Gets a list of MessageProcessor instances associated with this router
 

Methods in org.mule.api.routing with parameters of type MessageProcessor
 void SelectiveRouter.addRoute(MessageProcessor processor, Filter filter)
           
 void SelectiveRouter.removeRoute(MessageProcessor processor)
           
 void SelectiveRouter.setDefaultRoute(MessageProcessor processor)
           
 void SelectiveRouter.updateRoute(MessageProcessor processor, Filter filter)
           
 

Constructors in org.mule.api.routing with parameters of type MessageProcessor
CouldNotRouteOutboundMessageException(Message message, MuleEvent event, MessageProcessor target)
           
CouldNotRouteOutboundMessageException(Message message, MuleEvent event, MessageProcessor target, Throwable cause)
           
CouldNotRouteOutboundMessageException(MuleEvent event, MessageProcessor target)
           
CouldNotRouteOutboundMessageException(MuleEvent event, MessageProcessor target, Throwable cause)
           
ResponseTimeoutException(Message message, MuleEvent event, MessageProcessor target)
           
ResponseTimeoutException(Message message, MuleEvent event, MessageProcessor target, Throwable cause)
           
RoutePathNotFoundException(Message message, MuleEvent event, MessageProcessor target)
           
RoutePathNotFoundException(Message message, MuleEvent event, MessageProcessor target, Throwable cause)
           
RoutePathNotFoundException(MuleEvent event, MessageProcessor target)
           
RoutePathNotFoundException(MuleEvent event, MessageProcessor target, Throwable cause)
           
RoutingException(Message message, MuleEvent event, MessageProcessor route)
           
RoutingException(Message message, MuleEvent event, MessageProcessor route, Throwable cause)
           
RoutingException(MuleEvent event, MessageProcessor route)
           
RoutingException(MuleEvent event, MessageProcessor route, Throwable cause)
           
 

Uses of MessageProcessor in org.mule.api.service
 

Methods in org.mule.api.service that return MessageProcessor
 MessageProcessor Service.getOutboundMessageProcessor()
          Outbound Routers control how events are published by a service once.
 

Methods in org.mule.api.service with parameters of type MessageProcessor
 void Service.setOutboundMessageProcessor(MessageProcessor processor)
          Outbound message processor controls how events are published by a service once the event has been processed.
 

Uses of MessageProcessor in org.mule.api.source
 

Methods in org.mule.api.source with parameters of type MessageProcessor
 void MessageSource.setListener(MessageProcessor listener)
          Set the MessageProcessor listener on a message source which will be invoked when a message is received or generated.
 

Uses of MessageProcessor in org.mule.api.transformer
 

Subinterfaces of MessageProcessor in org.mule.api.transformer
 interface Converter
          Defines a Transformer that is a data type converters, ie: convert data from a type to another without modifying the meaning of the data.
 interface DiscoverableTransformer
          A interface to denote that a transformer is discoverable.
 interface MessageTransformer
          A transformer intended to transform Mule messages rather than arbitrary objects
 interface Transformer
          Transformer can be chained together to covert message payloads from one object type to another.
 

Uses of MessageProcessor in org.mule.api.transport
 

Subinterfaces of MessageProcessor in org.mule.api.transport
 interface MessageDispatcher
          Combine MessageDispatching with various lifecycle methods for the actual instances doing message sending.
 

Methods in org.mule.api.transport with parameters of type MessageProcessor
 void Connector.registerListener(InboundEndpoint endpoint, MessageProcessor listener, FlowConstruct flowConstruct)
          Registers a MessageProcessor listener which will listen to new message received from a specific transport channel and then processed by the endpoint.
 

Constructors in org.mule.api.transport with parameters of type MessageProcessor
DispatchException(Message message, MuleEvent event, MessageProcessor target)
           
DispatchException(Message message, MuleEvent event, MessageProcessor target, Throwable cause)
           
DispatchException(MuleEvent event, MessageProcessor target)
           
DispatchException(MuleEvent event, MessageProcessor target, Throwable cause)
           
 

Uses of MessageProcessor in org.mule.component
 

Classes in org.mule.component that implement MessageProcessor
 class AbstractComponent
          Abstract Component to be used by all Component implementations.
 class AbstractJavaComponent
          Abstract implementation of JavaComponent adds JavaComponent specifics like EntryPointResolverSet and ObjectFactory.
 class DefaultInterfaceBinding
           
 class DefaultJavaComponent
          Default implementation of JavaComponent.
 class PooledJavaComponent
          PooledJavaComponent implements pooling.
 class SimpleCallableJavaComponent
          Simple JavaComponent implementation to be used when LifecycleAdapter is not required because i) the object instance implements Callable and so entry-point resolution is required and ii) component bindings are not used.
An ObjectFactory can be set but must return object instances that implement Callable.
 

Uses of MessageProcessor in org.mule.component.simple
 

Classes in org.mule.component.simple that implement MessageProcessor
 class PassThroughComponent
          PassThroughComponent will simply return the payload back as the result.
 

Uses of MessageProcessor in org.mule.config.dsl.routers
 

Classes in org.mule.config.dsl.routers that implement MessageProcessor
 class ContentBasedRouter
          TODO
 

Uses of MessageProcessor in org.mule.config.i18n
 

Methods in org.mule.config.i18n with parameters of type MessageProcessor
static Message CoreMessages.errorInvokingMessageProcessorAsynchronously(MessageProcessor processor)
           
static Message CoreMessages.errorInvokingMessageProcessorWithinTransaction(MessageProcessor processor, TransactionConfig transactionConfig)
           
static Message CoreMessages.errorSchedulingMessageProcessorForAsyncInvocation(MessageProcessor processor)
           
static Message CoreMessages.failedToRouterViaEndpoint(MessageProcessor target)
           
 

Uses of MessageProcessor in org.mule.config.spring.factories
 

Fields in org.mule.config.spring.factories declared as MessageProcessor
protected  MessageProcessor PollingMessageSourceFactoryBean.messageProcessor
           
 

Methods in org.mule.config.spring.factories that return MessageProcessor
 MessageProcessor FlowRefFactoryBean.getObject()
           
protected  MessageProcessor FlowRefFactoryBean.getReferencedMessageProcessor(String name)
           
 

Methods in org.mule.config.spring.factories with parameters of type MessageProcessor
 void ValidatorFactoryBean.setMessageProcessor(MessageProcessor processor)
           
 void BridgeFactoryBean.setMessageProcessor(MessageProcessor processor)
           
 void SimpleServiceFactoryBean.setMessageProcessor(MessageProcessor component)
           
 void PollingMessageSourceFactoryBean.setMessageProcessor(MessageProcessor messageProcessor)
           
 

Method parameters in org.mule.config.spring.factories with type arguments of type MessageProcessor
 void MessageProcessorFilterPairFactoryBean.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 

Uses of MessageProcessor in org.mule.config.transformer
 

Classes in org.mule.config.transformer that implement MessageProcessor
 class AnnotatedTransformerProxy
          Creates a Mule Transformer proxy around a transform method.
 

Uses of MessageProcessor in org.mule.construct
 

Classes in org.mule.construct that implement MessageProcessor
 class AbstractPipeline.ProcessIfPipelineStartedMessageProcessor
           
 class Flow
          This implementation of AbstractPipeline adds the following functionality: Rejects inbound events when Flow is not started Gathers statistics and processing time data Implements MessagePorcessor allowing direct invocation of the pipeline Supports the optional configuration of a ProcessingStrategy that determines how message processors are processed.
 

Fields in org.mule.construct declared as MessageProcessor
protected  MessageProcessor AbstractPipeline.pipeline
           
 

Fields in org.mule.construct with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractPipeline.messageProcessors
           
protected  List<MessageProcessor> AbstractConfigurationPattern.responseTransformers
           
protected  List<MessageProcessor> AbstractConfigurationPattern.transformers
           
 

Methods in org.mule.construct that return MessageProcessor
protected  MessageProcessor AbstractPipeline.createPipeline()
          Creates a AbstractPipeline.ProcessIfPipelineStartedMessageProcessor that will process messages from the configured MessageSource .
 

Methods in org.mule.construct that return types with arguments of type MessageProcessor
 List<MessageProcessor> AbstractPipeline.getMessageProcessors()
           
 

Method parameters in org.mule.construct with type arguments of type MessageProcessor
 void AbstractPipeline.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 

Constructor parameters in org.mule.construct with type arguments of type MessageProcessor
AbstractConfigurationPattern(String name, MuleContext muleContext, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers)
           
AbstractConfigurationPattern(String name, MuleContext muleContext, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers)
           
Bridge(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, MessageExchangePattern exchangePattern, boolean transacted)
           
Bridge(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, MessageExchangePattern exchangePattern, boolean transacted)
           
SimpleService(String name, MuleContext muleContext, MessageSource messageSource, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, Component component, SimpleService.Type type)
           
SimpleService(String name, MuleContext muleContext, MessageSource messageSource, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, Component component, SimpleService.Type type)
           
 

Uses of MessageProcessor in org.mule.construct.builder
 

Fields in org.mule.construct.builder with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractFlowConstructBuilder.responseTransformers
           
protected  List<MessageProcessor> AbstractFlowConstructBuilder.transformers
           
 

Uses of MessageProcessor in org.mule.construct.processor
 

Classes in org.mule.construct.processor that implement MessageProcessor
 class FlowConstructStatisticsMessageProcessor
           
 

Uses of MessageProcessor in org.mule.context.notification
 

Methods in org.mule.context.notification that return MessageProcessor
 MessageProcessor MessageProcessorNotification.getProcessor()
           
 

Constructors in org.mule.context.notification with parameters of type MessageProcessor
MessageProcessorNotification(FlowConstruct flowConstruct, MuleEvent event, MessageProcessor processor, MessagingException exceptionThrown, int action)
           
 

Uses of MessageProcessor in org.mule.el
 

Classes in org.mule.el that implement MessageProcessor
 class ExpressionLanguageComponent
           
 

Uses of MessageProcessor in org.mule.endpoint
 

Classes in org.mule.endpoint that implement MessageProcessor
 class DefaultOutboundEndpoint
           
 class DynamicOutboundEndpoint
          An Outbound endpoint who's URI is a template used to created new non dynamic endpoints based on the current message.
 class DynamicURIOutboundEndpoint
          Allows EndpointURI to be set and changed dynamically by wrapping up an immutable endpoint instance.
 

Fields in org.mule.endpoint with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractEndpointBuilder.messageProcessors
           
protected  List<MessageProcessor> AbstractEndpointBuilder.responseMessageProcessors
           
 

Methods in org.mule.endpoint that return MessageProcessor
 MessageProcessor DefaultEndpointMessageProcessorChainFactory.createInboundMessageProcessorChain(InboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
protected  MessageProcessor DefaultOutboundEndpoint.createMessageProcessorChain(FlowConstruct flowContruct)
           
 MessageProcessor DefaultInboundEndpoint.createMessageProcessorChain(FlowConstruct flowContruct)
           
protected abstract  MessageProcessor AbstractEndpoint.createMessageProcessorChain(FlowConstruct flowContruct)
           
 MessageProcessor DefaultEndpointMessageProcessorChainFactory.createOutboundMessageProcessorChain(OutboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 MessageProcessor AbstractEndpoint.getMessageProcessorChain(FlowConstruct flowContruct)
           
protected  MessageProcessor DefaultInboundEndpoint.getPolledMessageProcessor()
           
protected  MessageProcessor EndpointMessageProcessorChainBuilder.initializeMessageProcessor(Object processor)
           
 

Methods in org.mule.endpoint that return types with arguments of type MessageProcessor
protected  List<MessageProcessor> AbstractEndpointBuilder.addReplyToProcessors(List<MessageProcessor> processors)
           
protected  List<MessageProcessor> AbstractEndpointBuilder.addResponseTransformerProcessors(EndpointURI endpointURI)
           
protected  List<MessageProcessor> AbstractEndpointBuilder.addTransformerProcessors(EndpointURI endpointURI)
           
protected  List<MessageProcessor> DefaultEndpointMessageProcessorChainFactory.createInboundMessageProcessors(InboundEndpoint endpoint)
          Override this method to change the default MessageProcessors.
protected  List<MessageProcessor> DefaultEndpointMessageProcessorChainFactory.createInboundResponseMessageProcessors(InboundEndpoint endpoint)
          Override this method to change the default MessageProcessors.
protected  List<MessageProcessor> DefaultEndpointMessageProcessorChainFactory.createOutboundMessageProcessors(OutboundEndpoint endpoint)
          Override this method to change the default MessageProcessors.
protected  List<MessageProcessor> DefaultEndpointMessageProcessorChainFactory.createOutboundResponseMessageProcessors(OutboundEndpoint endpoint)
          Override this method to change the default MessageProcessors.
 List<MessageProcessor> DynamicURIInboundEndpoint.getMessageProcessors()
           
 List<MessageProcessor> DynamicURIOutboundEndpoint.getMessageProcessors()
           
 List<MessageProcessor> AbstractEndpointBuilder.getMessageProcessors()
           
 List<MessageProcessor> DynamicOutboundEndpoint.getMessageProcessors()
           
 List<MessageProcessor> AbstractEndpoint.getMessageProcessors()
           
 List<MessageProcessor> DynamicURIInboundEndpoint.getResponseMessageProcessors()
           
 List<MessageProcessor> DynamicURIOutboundEndpoint.getResponseMessageProcessors()
           
 List<MessageProcessor> AbstractEndpointBuilder.getResponseMessageProcessors()
           
 List<MessageProcessor> DynamicOutboundEndpoint.getResponseMessageProcessors()
           
 List<MessageProcessor> AbstractEndpoint.getResponseMessageProcessors()
           
 

Methods in org.mule.endpoint with parameters of type MessageProcessor
 void AbstractEndpointBuilder.addMessageProcessor(MessageProcessor messageProcessor)
           
 void AbstractEndpointBuilder.addResponseMessageProcessor(MessageProcessor messageProcessor)
           
 MessageProcessor DefaultEndpointMessageProcessorChainFactory.createInboundMessageProcessorChain(InboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 MessageProcessor DefaultEndpointMessageProcessorChainFactory.createOutboundMessageProcessorChain(OutboundEndpoint endpoint, FlowConstruct flowConstruct, MessageProcessor target)
           
 void DynamicURIInboundEndpoint.setListener(MessageProcessor listener)
           
 void DefaultInboundEndpoint.setListener(MessageProcessor listener)
           
 

Method parameters in org.mule.endpoint with type arguments of type MessageProcessor
protected  List<MessageProcessor> AbstractEndpointBuilder.addReplyToProcessors(List<MessageProcessor> processors)
           
 void AbstractEndpointBuilder.setMessageProcessors(List<MessageProcessor> newMessageProcessors)
           
 void AbstractEndpointBuilder.setResponseMessageProcessors(List<MessageProcessor> newResponseMessageProcessors)
           
 

Constructor parameters in org.mule.endpoint with type arguments of type MessageProcessor
AbstractEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessages, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String endpointMimeType)
           
AbstractEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessages, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String endpointMimeType)
           
DefaultInboundEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessage, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String mimeType)
           
DefaultInboundEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessage, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String mimeType)
           
DefaultOutboundEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessage, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, String responsePropertiesList, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String endpointMimeType)
           
DefaultOutboundEndpoint(Connector connector, EndpointURI endpointUri, String name, Map properties, TransactionConfig transactionConfig, boolean deleteUnacceptedMessage, MessageExchangePattern messageExchangePattern, int responseTimeout, String initialState, String endpointEncoding, String endpointBuilderName, MuleContext muleContext, RetryPolicyTemplate retryPolicyTemplate, AbstractRedeliveryPolicy redeliveryPolicy, String responsePropertiesList, EndpointMessageProcessorChainFactory messageProcessorsFactory, List<MessageProcessor> messageProcessors, List<MessageProcessor> responseMessageProcessors, boolean disableTransportTransformer, String endpointMimeType)
           
 

Uses of MessageProcessor in org.mule.endpoint.inbound
 

Classes in org.mule.endpoint.inbound that implement MessageProcessor
 class InboundEndpointMimeTypeCheckingMessageProcessor
          Verify that the inbound mime type is acceptable by this endpoint.
 class InboundEndpointPropertyMessageProcessor
          Sets the inbound endpoint uri on as a property of the message using the following key: MuleProperties.MULE_ORIGINATING_ENDPOINT_PROPERTY.
 class InboundExceptionDetailsMessageProcessor
          Sets error message properties as specified by the transport based on the exception type of the exception payload.
 class InboundLoggingMessageProcessor
           
 class InboundNotificationMessageProcessor
          Publishes a EndpointMessageNotification's when a message is received.
 

Uses of MessageProcessor in org.mule.endpoint.outbound
 

Classes in org.mule.endpoint.outbound that implement MessageProcessor
 class OutboundEndpointMimeTypeCheckingMessageProcessor
          Verify that the outbound mime type is acceptable by this endpoint.
 class OutboundEndpointPropertyMessageProcessor
          Sets the outbound endpoint uri on as a property of the message using the following key: MuleProperties.MULE_ENDPOINT_PROPERTY.
 class OutboundEventTimeoutMessageProcessor
           
 class OutboundLoggingMessageProcessor
           
 class OutboundNotificationMessageProcessor
          Publishes a EndpointMessageNotification's when a message is sent or dispatched.
 class OutboundResponsePropertiesMessageProcessor
          Propagates properties from request message to response message as defined by OutboundEndpoint.getResponseProperties().
 class OutboundRewriteResponseEventMessageProcessor
           
 class OutboundRootMessageIdPropertyMessageProcessor
          Sets the outbound root message id on as a property of the message using the following key: MuleProperties.MULE_ROOT_MESSAGE_ID_PROPERTY.
 class OutboundSessionHandlerMessageProcessor
          Stores session information on the outbound message.
 class OutboundTxRollbackMessageProcessor
          MessageProcessor implementation that stops outbound flow is the current transaction has been rolled back.
 

Uses of MessageProcessor in org.mule.enricher
 

Classes in org.mule.enricher that implement MessageProcessor
 class MessageEnricher
          The Message Enricher allows the current message to be augmented using data from a seperate resource.
 

Methods in org.mule.enricher that return types with arguments of type MessageProcessor
protected  List<MessageProcessor> MessageEnricher.getOwnedMessageProcessors()
           
 

Methods in org.mule.enricher with parameters of type MessageProcessor
 void MessageEnricher.setEnrichmentMessageProcessor(MessageProcessor enrichmentProcessor)
           
 void MessageEnricher.setMessageProcessor(MessageProcessor enrichmentProcessor)
          For spring
 

Uses of MessageProcessor in org.mule.example.bookstore.transformers
 

Classes in org.mule.example.bookstore.transformers that implement MessageProcessor
 class AddBookResponse
          A call to addBook() returns a Long representing the number of books in the catalog.
 class HttpRequestToBook
          Transforms a Map of HttpRequest parameters into a Book object.
 class OrderToEmailTransformer
          Composes an e-mail notification message to be sent based on the Book Order.
 

Uses of MessageProcessor in org.mule.example.errorhandler
 

Classes in org.mule.example.errorhandler that implement MessageProcessor
 class ErrorMessageToException
          The ErrorMessageToException transformer extracts and returns the exception encapsulated by the ErrorMessage message payload.
 class ErrorMessageToExceptionBean
          The ErrorMessageToExceptionBean transformer returns the exception bean encapsulated by the ErrorMessage message payload.
 class ExceptionBeanToErrorMessage
           
 

Uses of MessageProcessor in org.mule.example.geomail.transformers
 

Classes in org.mule.example.geomail.transformers that implement MessageProcessor
 class IPToSender
          TODO
 

Uses of MessageProcessor in org.mule.example.hello
 

Classes in org.mule.example.hello that implement MessageProcessor
 class ChatStringToString
          NameStringToChatString is a dummy transformer used in the hello world application to transform the ChatString object into a string.
 class ExceptionToString
          ExceptionToString converts an exception to a String, returning the exception's getMessage() result.
 class HttpRequestToNameString
           
 class NameStringToChatString
          NameStringToChatString converts from a NameString object to a ChatString object.
 class StdinToNameString
          The transformation removes break-lines and newlines from the string, which potentially could have been added during a stdin input operation.
 class StringToNameString
          StringToNameString converts from a String to a NameString object.
 

Uses of MessageProcessor in org.mule.example.loanbroker.processor
 

Classes in org.mule.example.loanbroker.processor that implement MessageProcessor
 class LowestQuoteProcessor
           
 

Uses of MessageProcessor in org.mule.example.loanbroker.routers
 

Classes in org.mule.example.loanbroker.routers that implement MessageProcessor
 class BankQuotesInboundAggregator
          BankQuotesInboundAggregator receives a number of quotes and selects the lowest
 class BankQuotesResponseAggregator
          BankQuotesInboundAggregator receives a number of quotes and selects the lowest
 

Uses of MessageProcessor in org.mule.example.loanbroker.transformers
 

Classes in org.mule.example.loanbroker.transformers that implement MessageProcessor
 class CreditProfileXmlToCreditProfile
           
 class LoanQuoteRequestToCreditProfileArgs
          Extracts the customer information from the request into an array of arguments used to invoke the Credit Agency MuleSession bean
 class RestRequestToCustomerRequest
          Converts parameters on the message into a CustomerQuoteRequest object
 

Uses of MessageProcessor in org.mule.example.scripting
 

Classes in org.mule.example.scripting that implement MessageProcessor
 class SimpleMathTransformer
          A simple transformer which adds/subtracts/multiplies/divides a constant factor to numeric messages.
 

Uses of MessageProcessor in org.mule.exception
 

Classes in org.mule.exception that implement MessageProcessor
 class RedeliveryExceeded
           
 

Fields in org.mule.exception with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractExceptionListener.messageProcessors
           
 

Methods in org.mule.exception that return types with arguments of type MessageProcessor
 List<MessageProcessor> AbstractExceptionListener.getMessageProcessors()
           
 List<MessageProcessor> RedeliveryExceeded.getMessageProcessors()
           
protected  List<MessageProcessor> RollbackMessagingExceptionStrategy.getOwnedMessageProcessors()
           
protected  List<MessageProcessor> AbstractExceptionListener.getOwnedMessageProcessors()
           
 

Methods in org.mule.exception with parameters of type MessageProcessor
 void AbstractExceptionListener.addEndpoint(MessageProcessor processor)
           
 boolean AbstractExceptionListener.removeMessageProcessor(MessageProcessor processor)
           
protected  void AbstractExceptionListener.routeException(MuleEvent event, MessageProcessor target, Throwable t)
          Deprecated. use AbstractExceptionListener.routeException(org.mule.api.MuleEvent, Throwable) instead
 

Method parameters in org.mule.exception with type arguments of type MessageProcessor
 void AbstractExceptionListener.setMessageProcessors(List<MessageProcessor> processors)
           
 void RedeliveryExceeded.setMessageProcessors(List<MessageProcessor> processors)
           
 

Uses of MessageProcessor in org.mule.execution
 

Methods in org.mule.execution with parameters of type MessageProcessor
 MuleEvent MessageProcessorExecutionInterceptor.execute(MessageProcessor messageProcessor, MuleEvent event)
           
 MuleEvent ExceptionToMessagingExceptionExecutionInterceptor.execute(MessageProcessor messageProcessor, MuleEvent event)
           
 MuleEvent MessageProcessorExecutionTemplate.execute(MessageProcessor messageProcessor, MuleEvent event)
           
 

Uses of MessageProcessor in org.mule.expression
 

Methods in org.mule.expression that return MessageProcessor
protected  MessageProcessor MessageProcessorExpressionEvaluator.lookupMessageProcessor(String processorName, MuleContext muleContext)
           
 

Uses of MessageProcessor in org.mule.expression.transformers
 

Classes in org.mule.expression.transformers that implement MessageProcessor
 class AbstractExpressionTransformer
          This transformer will evaluate one or more expressions on the current message and return the results as an Array.
 class BeanBuilderTransformer
          This transformer uses the returnClass to create the return object and then will populate the bean with arguments defined as expressions
 class ExpressionTransformer
          This transformer will evaluate one or more expressions on the current message and return the results as an Array.
 

Uses of MessageProcessor in org.mule.interceptor
 

Classes in org.mule.interceptor that implement MessageProcessor
 class AbstractEnvelopeInterceptor
          EnvelopeInterceptor is an intercepter that will fire before and after an event is received.
 class InterceptorStack
          Maintains a list of interceptors that can be applied to components.
 class LoggingInterceptor
          LoggingInterceptor is a simple interceptor that logs a message before and after the event processing.
 class ProcessingTimeInterceptor
          Calculate and record the processing time for a message processing chain
 class TimerInterceptor
          TimerInterceptor simply times and displays the time taken to process an event.
 

Constructors in org.mule.interceptor with parameters of type MessageProcessor
ProcessingTimeInterceptor(MessageProcessor next, FlowConstruct fc)
           
 

Uses of MessageProcessor in org.mule.lifecycle.processor
 

Classes in org.mule.lifecycle.processor that implement MessageProcessor
 class ProcessIfStartedMessageProcessor
           
 class ProcessIfStartedWaitIfPausedMessageProcessor
           
 class ProcessIfStartedWaitIfSyncPausedMessageProcessor
           
 

Uses of MessageProcessor in org.mule.model.seda
 

Classes in org.mule.model.seda that implement MessageProcessor
 class SedaService
          A Seda service runs inside a Seda Model and is responsible for managing a Seda Queue and thread pool for a Mule sevice service.
 

Methods in org.mule.model.seda that return MessageProcessor
protected  MessageProcessor SedaService.getServiceStartedAssertingMessageProcessor()
           
 

Uses of MessageProcessor in org.mule.module.atom
 

Classes in org.mule.module.atom that implement MessageProcessor
 class AbderaServiceComponent
          This component receives requests from Mule and passes them off to Abdera.
 

Uses of MessageProcessor in org.mule.module.atom.routing
 

Classes in org.mule.module.atom.routing that implement MessageProcessor
 class FeedSplitter
          An inbound router that will split a Feed into entries.
 

Uses of MessageProcessor in org.mule.module.atom.transformers
 

Classes in org.mule.module.atom.transformers that implement MessageProcessor
 class AtomEntryBuilderTransformer
           
 class BaseToOutputHandler
          Converts Abdera model elements which extend Base to OutputHandlers.
 class ObjectToFeed
          ObjectToInputStream converts serilaizable object to a input stream but treats java.lang.String differently by converting to bytes using the String.getBytes() method.
 

Uses of MessageProcessor in org.mule.module.bpm
 

Classes in org.mule.module.bpm that implement MessageProcessor
 class ProcessComponent
          A service backed by the execution of a business process such as jBPM.
 class RulesComponent
          A service backed by a Business Rules engine such as Drools.
 

Uses of MessageProcessor in org.mule.module.cxf
 

Classes in org.mule.module.cxf that implement MessageProcessor
 class CxfInboundMessageProcessor
          The CxfInboundMessageProcessor performs inbound CXF processing, sending an event through the CXF service, then on to the next MessageProcessor.
 class CxfOutboundMessageProcessor
          The CxfOutboundMessageProcessor performs outbound CXF processing, sending an event through the CXF client, then on to the next MessageProcessor.
 

Uses of MessageProcessor in org.mule.module.cxf.component
 

Classes in org.mule.module.cxf.component that implement MessageProcessor
 class AbstractWebServiceWrapperComponent
           
 class WebServiceWrapperComponent
          Deprecated. 
 

Uses of MessageProcessor in org.mule.module.cxf.config
 

Classes in org.mule.module.cxf.config that implement MessageProcessor
 class FlowConfiguringMessageProcessor
          Wraps a MessageProcessorBuilder and configures it lazily so it can be injected with the FlowConstruct.
 

Methods in org.mule.module.cxf.config that return MessageProcessor
 MessageProcessor FlowConfiguringMessageProcessor.getWrappedMessageProcessor()
          The MessageProcessor that this class built.
 

Methods in org.mule.module.cxf.config with parameters of type MessageProcessor
 void FlowConfiguringMessageProcessor.setListener(MessageProcessor listener)
           
 

Uses of MessageProcessor in org.mule.module.ibeans.config
 

Classes in org.mule.module.ibeans.config that implement MessageProcessor
 class CallInterfaceBinding
          An instance of a binding that matches iBean method name with an endpoint to invoke.
 class IBeanBinding
          TODO
 class IBeanFlowConstruct
          This is an empty flow construct that is used to host an iBean as a component with one or more component bindings.
 

Uses of MessageProcessor in org.mule.module.ibeans.spi.support
 

Classes in org.mule.module.ibeans.spi.support that implement MessageProcessor
 class CallOutboundEndpoint
           A dynamic outbound endpoint defined when using the Call annotation.
 class DefaultRequestInterfaceBinding
          Used for making a request from a message dispatcher
 class DynamicRequestInterfaceBinding
          Creates an component binding that can use the MessageRequester interface to make a call.
 

Methods in org.mule.module.ibeans.spi.support that return MessageProcessor
 MessageProcessor DynamicRequestEndpoint.NullInboundEndpoint.createMessageProcessorChain(FlowConstruct flowContruct)
           
 

Uses of MessageProcessor in org.mule.module.jca
 

Classes in org.mule.module.jca that implement MessageProcessor
 class JcaComponent
           
 class JcaService
          JcaService Is the type of service used in Mule when embedded inside an app server using JCA.
 

Uses of MessageProcessor in org.mule.module.jersey
 

Classes in org.mule.module.jersey that implement MessageProcessor
 class JerseyResourcesComponent
          Wraps a set of components which can get invoked by Jersey.
 

Method parameters in org.mule.module.jersey with type arguments of type MessageProcessor
 void JerseyResourcesComponent.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 

Uses of MessageProcessor in org.mule.module.json.transformers
 

Classes in org.mule.module.json.transformers that implement MessageProcessor
 class AbstractJsonTransformer
          TODO
 class AbstractToFromXmlTransformer
          Superclass for transformers that convert JSON to and from XML
 class JsonToObject
          A transformer that will convert a JSON encoded object graph to a java object.
 class JsonToXml
          Convert JSON to an XML document string
 class JsonXsltTransformer
          Convert Json to Json using XSLT
 class ObjectToJson
          Converts a java object to a JSON encoded object that can be consumed by other languages such as Javascript or Ruby.
 class XmlToJson
          Convert XML to a JSON string
 

Uses of MessageProcessor in org.mule.module.rss.transformers
 

Classes in org.mule.module.rss.transformers that implement MessageProcessor
 class ObjectToRssFeed
          Converts an RSS data representation into a SyndFeed object
 

Uses of MessageProcessor in org.mule.module.scripting.component
 

Classes in org.mule.module.scripting.component that implement MessageProcessor
 class ScriptComponent
          A Script service backed by a JSR-223 compliant script engine such as Groovy, JavaScript, or Rhino.
 

Uses of MessageProcessor in org.mule.module.scripting.filter
 

Classes in org.mule.module.scripting.filter that implement MessageProcessor
 class ScriptFilter
           
 

Uses of MessageProcessor in org.mule.module.scripting.transformer
 

Classes in org.mule.module.scripting.transformer that implement MessageProcessor
 class ScriptTransformer
          Runs a script to perform transformation on an object.
 

Uses of MessageProcessor in org.mule.module.spring.remoting
 

Classes in org.mule.module.spring.remoting that implement MessageProcessor
 class ObjectToRemoteInvocationResultTransformer
          Converts an Object to a Spring RemoteInvocationResult and then into a byte[].
 class ObjectToRemoteInvocationTransformer
          Transforms a byte[] into an ObjectInputStream and then into a Spring RemoteInvocation instance.
 

Uses of MessageProcessor in org.mule.module.sxc
 

Classes in org.mule.module.sxc that implement MessageProcessor
 class SxcFilteringOutboundRouter
          FilteringRouter is a router that accepts events based on a filter set.
 

Uses of MessageProcessor in org.mule.module.ws.config.spring.factories
 

Methods in org.mule.module.ws.config.spring.factories with parameters of type MessageProcessor
 void WSProxyFactoryBean.setMessageProcessor(MessageProcessor processor)
           
 

Uses of MessageProcessor in org.mule.module.ws.construct
 

Constructor parameters in org.mule.module.ws.construct with type arguments of type MessageProcessor
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers)
           
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers)
           
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, String wsdlContents)
           
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, String wsdlContents)
           
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, URI wsdlUri)
           
WSProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, URI wsdlUri)
           
 

Uses of MessageProcessor in org.mule.module.xml.routing
 

Classes in org.mule.module.xml.routing that implement MessageProcessor
 class FilterBasedXmlMessageSplitter
          This splitter will select the endpoint to send a message part on by filtering parts using the endpoint filters.
 class XmlMessageSplitter
          XmlMessageSplitter will split a DOM4J document into nodes based on the "splitExpression" property.
 

Uses of MessageProcessor in org.mule.module.xml.transformer
 

Classes in org.mule.module.xml.transformer that implement MessageProcessor
 class AbstractXmlTransformer
          AbstractXmlTransformer offers some XSLT transform on a DOM (or other XML-ish) object.
 class AbstractXStreamTransformer
          AbstractXStreamTransformer is a base class for all XStream based transformers.
 class DomDocumentToXml
          DomDocumentToXml Transform a org.w3c.dom.Document to XML String
 class JXPathExtractor
          The JXPathExtractor is a simple transformer that evaluates an xpath expression against the given bean and that returns the result.
 class ObjectToXml
          ObjectToXml converts any object to XML using Xstream.
 class XmlPrettyPrinter
           
 class XmlToDomDocument
          XmlToDomDocument transforms a XML String to org.w3c.dom.Document.
 class XmlToObject
          XmlToObject converts xml created by the ObjectToXml transformer in to a java object graph.
 class XmlToOutputHandler
           
 class XmlToXMLStreamReader
           
 class XPathExtractor
          Simple transformer for using the JAXP XPath library to extract an XPath value from an XPath expression.
 class XQueryTransformer
          The XQuery Module gives users the ability to perform XQuery transformations on XML messages in Mule
 class XsltTransformer
          XsltTransformer performs an XSLT transform on a DOM (or other XML-ish) object.
 

Uses of MessageProcessor in org.mule.module.xml.transformer.jaxb
 

Classes in org.mule.module.xml.transformer.jaxb that implement MessageProcessor
 class JAXBMarshallerTransformer
          Allows marshaling of Java objects to XML using JAXB 2.
 class JAXBUnmarshallerTransformer
          Allows un-marshaling of XML generated by JAXB to a Java object graph.
 

Uses of MessageProcessor in org.mule.processor
 

Classes in org.mule.processor that implement MessageProcessor
 class AbstractDynamicMessageProcessor
          Implementation of MessageProcessor that dynamically chooses and uses another MessageProcessor
 class AbstractFilteringMessageProcessor
          Abstract InterceptingMessageProcessor that can be easily be extended and used for filtering message flow through a MessageProcessor chain.
 class AbstractInterceptingMessageProcessor
          Abstract implementation of InterceptingMessageProcessor that simply provides an implementation of setNext and holds the next message processor as an attribute.
 class AbstractInterceptingMessageProcessorBase
          Abstract implementation that provides the infrastructure for intercepting message processors.
 class AbstractRedeliveryPolicy
          Implement a redelivery policy for Mule.
 class AbstractResponseMessageProcessor
           
 class AsyncDelegateMessageProcessor
          Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of MessageProcessor delegate configured the next MessageProcessor.
 class AsyncInterceptingMessageProcessor
          Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
 class EndpointTransactionalInterceptingMessageProcessor
          Wraps the invocation of the next MessageProcessor with a transaction.
 class ExceptionHandlingMessageProcessor
           
 class IdempotentRedeliveryPolicy
          Implement a retry policy for Mule.
 class InvokerMessageProcessor
          InvokerMessageProcessor invokes a specified method of an object.
 class LaxAsyncInterceptingMessageProcessor
           
 class LaxSedaStageInterceptingMessageProcessor
          Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
 class NullMessageProcessor
           
 class ResponseMessageProcessorAdapter
           
 class SecurityFilterMessageProcessor
          Filters the flow using the specified SecurityFilter.
 class SedaStageInterceptingMessageProcessor
          Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
 class StopFurtherMessageProcessingMessageProcessor
           
 class TransactionalInterceptingMessageProcessor
          Wraps the invocation of the next MessageProcessor with a transaction.
 

Fields in org.mule.processor declared as MessageProcessor
protected  MessageProcessor AbstractRedeliveryPolicy.deadLetterQueue
           
protected  MessageProcessor AsyncDelegateMessageProcessor.delegate
           
protected  MessageProcessor AbstractInterceptingMessageProcessorBase.next
           
protected  MessageProcessor ResponseMessageProcessorAdapter.responseProcessor
           
protected  MessageProcessor AsyncWorkListener.target
           
protected  MessageProcessor AbstractFilteringMessageProcessor.unacceptedMessageProcessor
          The MessageProcessor that should be used to handle messages that are not accepted by the filter.
 

Fields in org.mule.processor with type parameters of type MessageProcessor
protected  List<MessageProcessor> AsyncDelegateMessageProcessor.processors
           
 

Methods in org.mule.processor that return MessageProcessor
 MessageProcessor AbstractInterceptingMessageProcessorBase.getListener()
           
 MessageProcessor AbstractRedeliveryPolicy.getTheFailedMessageProcessor()
           
 MessageProcessor AbstractFilteringMessageProcessor.getUnacceptedMessageProcessor()
           
protected abstract  MessageProcessor AbstractDynamicMessageProcessor.resolveMessageProcessor(MuleEvent event)
          Determines which MessageProcessor should be used.
 

Methods in org.mule.processor that return types with arguments of type MessageProcessor
 List<MessageProcessor> NullMessageProcessor.getMessageProcessors()
           
protected  List<MessageProcessor> AsyncDelegateMessageProcessor.getOwnedMessageProcessors()
           
protected abstract  List<MessageProcessor> AbstractMessageProcessorOwner.getOwnedMessageProcessors()
           
protected  List<MessageProcessor> AbstractMessageProcessorOwner.getOwnedObjects()
           
 

Methods in org.mule.processor with parameters of type MessageProcessor
 void AsyncDelegateMessageProcessor.setDelegate(MessageProcessor delegate)
           
 void AbstractInterceptingMessageProcessorBase.setListener(MessageProcessor next)
           
 void IdempotentRedeliveryPolicy.setMessageProcessor(MessageProcessor processor)
           
 void ResponseMessageProcessorAdapter.setProcessor(MessageProcessor processor)
           
 void AbstractFilteringMessageProcessor.setUnacceptedMessageProcessor(MessageProcessor unacceptedMessageProcessor)
           
 

Constructors in org.mule.processor with parameters of type MessageProcessor
AsyncDelegateMessageProcessor(MessageProcessor delegate, ProcessingStrategy processingStrategy, String name)
           
AsyncWorkListener(MessageProcessor target)
           
ResponseMessageProcessorAdapter(MessageProcessor responseProcessor)
           
 

Uses of MessageProcessor in org.mule.processor.chain
 

Classes in org.mule.processor.chain that implement MessageProcessor
 class AbstractMessageProcessorChain
          Builder needs to return a composite rather than the first MessageProcessor in the chain.
 class DefaultMessageProcessorChain
           
 class InterceptingChainLifecycleWrapper
          Builder needs to return a composite rather than the first MessageProcessor in the chain.
 class SimpleMessageProcessorChain
           
 

Fields in org.mule.processor.chain with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractMessageProcessorChain.processors
           
 

Methods in org.mule.processor.chain that return MessageProcessor
protected  MessageProcessor AbstractMessageProcessorChainBuilder.initializeMessageProcessor(Object processor)
           
 

Methods in org.mule.processor.chain that return types with arguments of type MessageProcessor
 List<MessageProcessor> AbstractMessageProcessorChain.getMessageProcessors()
           
 List<MessageProcessor> InterceptingChainLifecycleWrapper.getMessageProcessors()
           
 

Methods in org.mule.processor.chain with parameters of type MessageProcessor
 DefaultMessageProcessorChainBuilder DefaultMessageProcessorChainBuilder.chain(MessageProcessor... processors)
           
 DefaultMessageProcessorChainBuilder DefaultMessageProcessorChainBuilder.chainBefore(MessageProcessor processor)
           
static MessageProcessorChain DefaultMessageProcessorChain.from(MessageProcessor... messageProcessors)
           
static MessageProcessorChain DefaultMessageProcessorChain.from(MessageProcessor messageProcessor)
           
protected  boolean DefaultMessageProcessorChain.processorMayReturnNull(MessageProcessor processor)
           
 

Method parameters in org.mule.processor.chain with type arguments of type MessageProcessor
 DefaultMessageProcessorChainBuilder DefaultMessageProcessorChainBuilder.chain(List<MessageProcessor> processors)
           
protected  DefaultMessageProcessorChain SimpleMessageProcessorChainBuilder.createInnerChain(LinkedList<MessageProcessor> tempList)
           
protected  DefaultMessageProcessorChain DefaultMessageProcessorChainBuilder.createInnerChain(LinkedList<MessageProcessor> tempList)
           
protected  DefaultMessageProcessorChain SimpleMessageProcessorChainBuilder.createOuterChain(LinkedList<MessageProcessor> tempList)
           
protected  DefaultMessageProcessorChain DefaultMessageProcessorChainBuilder.createOuterChain(LinkedList<MessageProcessor> tempList)
           
static MessageProcessorChain DefaultMessageProcessorChain.from(List<MessageProcessor> messageProcessors)
           
 

Constructors in org.mule.processor.chain with parameters of type MessageProcessor
DefaultMessageProcessorChain(MessageProcessor... processors)
           
DefaultMessageProcessorChain(String name, MessageProcessor... processors)
           
SimpleMessageProcessorChain(MessageProcessor... processors)
           
SimpleMessageProcessorChain(String name, MessageProcessor... processors)
           
 

Constructor parameters in org.mule.processor.chain with type arguments of type MessageProcessor
AbstractMessageProcessorChain(String name, List<MessageProcessor> processors)
           
DefaultMessageProcessorChain(List<MessageProcessor> processors)
           
DefaultMessageProcessorChain(String name, List<MessageProcessor> processors)
           
InterceptingChainLifecycleWrapper(MessageProcessorChain chain, List<MessageProcessor> processors, String name)
           
SimpleMessageProcessorChain(List<MessageProcessor> processors)
           
SimpleMessageProcessorChain(String name, List<MessageProcessor> processors)
           
 

Uses of MessageProcessor in org.mule.processor.strategy
 

Method parameters in org.mule.processor.strategy with type arguments of type MessageProcessor
 void QueuedThreadPerProcessorProcessingStrategy.configureProcessors(List<MessageProcessor> processors, ProcessingStrategy.StageNameSource nameSource, MessageProcessorChainBuilder builder, MuleContext muleContext)
           
 void AsynchronousProcessingStrategy.configureProcessors(List<MessageProcessor> processors, ProcessingStrategy.StageNameSource nameSource, MessageProcessorChainBuilder chainBuilder, MuleContext muleContext)
           
 void SynchronousProcessingStrategy.configureProcessors(List<MessageProcessor> processors, ProcessingStrategy.StageNameSource nameSource, MessageProcessorChainBuilder chainBuilder, MuleContext muleContext)
           
 void ThreadPerProcessorProcessingStrategy.configureProcessors(List<MessageProcessor> processors, ProcessingStrategy.StageNameSource nameSource, MessageProcessorChainBuilder builder, MuleContext muleContext)
           
 

Uses of MessageProcessor in org.mule.routing
 

Classes in org.mule.routing that implement MessageProcessor
 class AbstractAggregator
          AbstractEventAggregator will aggregate a set of messages into a single message.
 class AbstractCatchAllStrategy
          RouterCatchAllStrategy is a strategy interface that allows developers to hook in custom code when an event is being routed on the inbound or outbound but does not match any of the criteria defined for the routing.
 class AbstractCorrelationAggregator
          AbstractCorrelationAggregatingMessageProcessor uses the CorrelationID and CorrelationGroupSize properties of the MuleMessage to manage message groups.
 class AbstractMatchingRouter
          AbstractRouterCollection provides common method implementations of router collections for in and outbound routers.
 class AbstractSelectiveRouter
           
 class AbstractSplitter
          Splits a message invoking the next message processor one for each split part.
 class ChoiceRouter
          Routes the event to a singleMessageProcessor using a Filter to evaluate the event being processed and find the first route that can be used.
 class CollectionSplitter
          Splits a message that has a Collection, Iterable, MessageSequence or Iterator payload invoking the next message processor one for each item in it.
 class ExpressionSplitter
          Splits a message using the expression provided invoking the next message processor one for each split part.
 class FirstSuccessful
          FirstSuccessful routes an event to the first target route that can accept it without throwing or returning an exception.
 class Foreach
          ` * The Foreach MessageProcessor allows iterating over a collection payload, or any collection obtained by an expression, generating a message for each element.
 class ForwardingCatchAllStrategy
          ForwardingCatchAllStrategy acts as a catch and forward router for any events not caught by the router this strategy is associated with.
 class IdempotentMessageFilter
          IdempotentMessageFilter ensures that only unique messages are passed on.
 class IdempotentSecureHashMessageFilter
          IdempotentSecureHashMessageFilter ensures that only unique messages are received by a service.
 class LoggingCatchAllStrategy
          LoggingCatchAllStrategy is a simple strategy that only logs any events not caught by the router associated with this strategy.
 class MapSplitter
          Splits a message that has a map payload invoking the next message processor one for each item in the map in order.
 class MessageChunkAggregator
           
 class MessageChunkSplitter
          A router that breaks up the current message onto smaller parts and sends them to the same destination.
 class MessageFilter
          Implementation of InterceptingMessageProcessor that filters message flow using a Filter.
 class Resequencer
          Resequencer is used to resequence events according to their dispatch sequence in the correlation group.
 class RoundRobin
          RoundRobin divides the messages it receives among its target routes in round-robin fashion.
 class ServiceCatchAllStrategy
          Deprecated.  
 class SimpleCollectionAggregator
          This router will return all aggregated events as a MuleMessageCollection.
 class UntilSuccessful
          UntilSuccessful attempts to route a message to the message processor it contains in an asynchronous manner.
 class WireTap
          The WireTap MessageProcessor allows inspection of messages in a flow.
 

Fields in org.mule.routing declared as MessageProcessor
protected  MessageProcessor AbstractMatchingRouter.defaultRoute
           
protected  MessageProcessor WireTap.filteredTap
           
protected  MessageProcessor WireTap.tap
           
 

Methods in org.mule.routing that return MessageProcessor
 MessageProcessor AbstractMatchingRouter.getDefaultRoute()
           
 MessageProcessor MessageProcessorFilterPair.getMessageProcessor()
           
 MessageProcessor WireTap.getTap()
           
 

Methods in org.mule.routing that return types with arguments of type MessageProcessor
protected  List<MessageProcessor> WireTap.getOwnedMessageProcessors()
           
protected  List<MessageProcessor> Foreach.getOwnedMessageProcessors()
           
protected abstract  Collection<MessageProcessor> AbstractSelectiveRouter.selectProcessors(MuleEvent event)
           
protected  Collection<MessageProcessor> ChoiceRouter.selectProcessors(MuleEvent event)
           
 

Methods in org.mule.routing with parameters of type MessageProcessor
 void AbstractSelectiveRouter.addRoute(MessageProcessor processor, Filter filter)
           
protected  MuleEvent FirstSuccessful.cloneEventForRoutinng(MuleEvent event, MessageProcessor mp)
           
 void AbstractSelectiveRouter.removeRoute(MessageProcessor processor)
           
 void AbstractSelectiveRouter.setDefaultRoute(MessageProcessor processor)
           
 void AbstractMatchingRouter.setDefaultRoute(MessageProcessor defaultRoute)
           
 void Foreach.setListener(MessageProcessor listener)
           
 void WireTap.setMessageProcessor(MessageProcessor tap)
          Deprecated. 
 void ForwardingCatchAllStrategy.setMessageProcessor(MessageProcessor processor)
           
 void WireTap.setTap(MessageProcessor tap)
           
 void AbstractSelectiveRouter.updateRoute(MessageProcessor processor, Filter filter)
           
 

Method parameters in org.mule.routing with type arguments of type MessageProcessor
 void Foreach.setMessageProcessors(List<MessageProcessor> messageProcessors)
           
 

Constructors in org.mule.routing with parameters of type MessageProcessor
AggregationException(EventGroup eventGroup, MessageProcessor endpoint)
           
AggregationException(EventGroup eventGroup, MessageProcessor endpoint, Throwable cause)
           
AggregationException(Message message, EventGroup eventGroup, MessageProcessor endpoint)
           
AggregationException(Message message, EventGroup eventGroup, MessageProcessor endpoint, Throwable cause)
           
MessageFilter(Filter filter, boolean throwExceptionOnUnaccepted, MessageProcessor messageProcessor)
           
MessageProcessorFilterPair(MessageProcessor messageProcessor, Filter filter)
           
 

Uses of MessageProcessor in org.mule.routing.correlation
 

Constructors in org.mule.routing.correlation with parameters of type MessageProcessor
EventCorrelator(EventCorrelatorCallback callback, MessageProcessor timeoutMessageProcessor, MessageInfoMapping messageInfoMapping, MuleContext muleContext, String flowConstructName, boolean persistentStores, String storePrefix)
           
 

Uses of MessageProcessor in org.mule.routing.outbound
 

Classes in org.mule.routing.outbound that implement MessageProcessor
 class AbstractMessageSequenceSplitter
          Base implementation of a MuleMessage splitter, that converts its payload in a MessageSequence, and process each element of it.
 class AbstractMessageSplitter
          AbstractMessageSplitter is an outbound Message Splitter used to split the contents of a received message into sub parts that can be processed by other components.
 class AbstractOutboundRouter
          AbstractOutboundRouter is a base router class that tracks statistics about message processing through the router.
 class AbstractRecipientList
          AbstractRecipientList is used to dispatch a single event to multiple recipients over the same transport.
 class AbstractRoundRobinMessageSplitter
          FilteringListMessageSplitter accepts a List as a message payload then routes list elements as messages over an endpoint where the endpoint's filter accepts the payload.
 class AbstractSequenceRouter
          Defines a router that sequentially routes a given message to the list of registered endpoints and returns the aggregate responses as the result.
 class ChainingRouter
          ChainingRouter is used to pass a Mule event through multiple targets using the result of the first as the input for the second.
 class DefaultOutboundRouterCollection
          DefaultOutboundRouterCollection is a container of routers.
 class EndpointSelector
          EndpointSelector selects the outgoing endpoint based on a an expression evaluator ("header:endpoint" by default).
 class ExceptionBasedRouter
          ExceptionBasedRouter Will send the current event to the first endpoint that doesn't throw an exception.
 class ExpressionMessageSplitter
          Evaluates a single expression and adds the results of the expression as individual message parts.
 class ExpressionRecipientList
           
 class FilteringOutboundRouter
          FilteringRouter is a router that accepts events based on a filter set.
 class ListMessageSplitter
          FilteringListMessageSplitter accepts a List as a message payload then routes list elements as messages over an endpoint where the endpoint's filter accepts the payload.
 class MessageChunkingRouter
          A router that breaks up the current message onto smaller parts and sends them to the same destination.
 class MulticastingRouter
          MulticastingRouter will broadcast the current message to every endpoint registered with the router.
 class OutboundPassThroughRouter
          OutboundPassThroughRouter allows outbound routing over a single endpoint without any filtering.
 class SequenceRouter
          Defines a AbstractSequenceRouter that stops the routing of a given message when a synchronous endpoint has returned a null or an exception message.
 class StaticRecipientList
          StaticRecipientList is used to dispatch a single event to multiple recipients over the same transport.
 class TransformerRouter
          Deprecated.  
 

Fields in org.mule.routing.outbound with type parameters of type MessageProcessor
protected  List<MessageProcessor> AbstractOutboundRouter.routes
           
 

Methods in org.mule.routing.outbound that return MessageProcessor
 MessageProcessor FilteringOutboundRouter.getRoute(int index, MuleEvent event)
          Will Return the target at the given index and will resolve any template tags on the Endpoint URI if necessary
 MessageProcessor AbstractOutboundRouter.getRoute(String name)
           
protected  MessageProcessor EndpointSelector.lookupEndpoint(String endpointName)
           
 

Methods in org.mule.routing.outbound that return types with arguments of type MessageProcessor
protected  List<MessageProcessor> AbstractOutboundRouter.getOwnedMessageProcessors()
           
 List<MessageProcessor> AbstractOutboundRouter.getRoutes()
           
 

Methods in org.mule.routing.outbound with parameters of type MessageProcessor
 void AbstractOutboundRouter.addRoute(MessageProcessor route)
           
 void FilteringOutboundRouter.addRoute(MessageProcessor target)
           
 void OutboundPassThroughRouter.addRoute(MessageProcessor target)
           
protected  MuleEvent AbstractOutboundRouter.createEventToRoute(MuleEvent routedEvent, MuleMessage message, MessageProcessor route)
          Create a new event to be routed to the target MP
 void AbstractOutboundRouter.removeRoute(MessageProcessor route)
           
protected  MuleEvent AbstractOutboundRouter.sendRequest(MuleEvent routedEvent, MuleMessage message, MessageProcessor route, boolean awaitResponse)
           
protected  MuleEvent AbstractOutboundRouter.sendRequestEvent(MuleEvent routedEvent, MuleMessage message, MessageProcessor route, boolean awaitResponse)
          Send message event to destination.
protected  void AbstractOutboundRouter.setMessageProperties(FlowConstruct service, MuleMessage message, MessageProcessor route)
           
 

Method parameters in org.mule.routing.outbound with type arguments of type MessageProcessor
protected  SplitMessage AbstractRoundRobinMessageSplitter.getMessageParts(MuleMessage message, List<MessageProcessor> endpoints)
          Retrieves a specific message part for the given endpoint.
protected abstract  SplitMessage AbstractMessageSplitter.getMessageParts(MuleMessage message, List<MessageProcessor> endpoints)
          Implementing classes should create a SplitMessage instance and for each part can associate an endpoint.
 void AbstractOutboundRouter.setMessageProcessors(List<MessageProcessor> routes)
          Deprecated. 
 void AbstractOutboundRouter.setRoutes(List<MessageProcessor> routes)
           
 void OutboundPassThroughRouter.setRoutes(List<MessageProcessor> endpoints)
           
 

Uses of MessageProcessor in org.mule.routing.requestreply
 

Classes in org.mule.routing.requestreply that implement MessageProcessor
 class AbstractAsyncRequestReplyRequester
           
 class AbstractReplyToPropertyRequestReplyReplier
           
 class AsyncReplyToPropertyRequestReplyReplier
           
 class ReplyToParameterProcessor
          Propagate any replyTo parameter from the event's message to the event itself.
 class ReplyToPropertyRequestReplyReplier
           
 class SimpleAsyncRequestReplyRequester
           
 class SimpleRequestReplyReplier
           
 

Fields in org.mule.routing.requestreply declared as MessageProcessor
protected  MessageProcessor SimpleRequestReplyReplier.replyMessageProcessor
           
protected  MessageProcessor SimpleAsyncRequestReplyRequester.requestMessageProcessor
           
 

Methods in org.mule.routing.requestreply with parameters of type MessageProcessor
 void SimpleAsyncRequestReplyRequester.setMessageProcessor(MessageProcessor processor)
           
 void SimpleRequestReplyReplier.setReplyProcessor(MessageProcessor replyMessageProcessor)
           
 void AbstractReplyToPropertyRequestReplyReplier.setReplyProcessor(MessageProcessor replyMessageProcessor)
           
 

Uses of MessageProcessor in org.mule.service
 

Classes in org.mule.service that implement MessageProcessor
 class AbstractService
          A base implementation for all Services in Mule
 class ForwardingConsumer
          Deprecated.  
 

Fields in org.mule.service declared as MessageProcessor
protected  MessageProcessor ServiceCompositeMessageSource.catchAllStrategy
           
protected  MessageProcessor AbstractService.outboundRouter
           
 

Fields in org.mule.service with type parameters of type MessageProcessor
protected  List<MessageProcessor> ServiceCompositeMessageSource.processors
           
 

Methods in org.mule.service that return MessageProcessor
 MessageProcessor ServiceCompositeMessageSource.getCatchAllStrategy()
           
 MessageProcessor AbstractService.getOutboundMessageProcessor()
           
protected  MessageProcessor AbstractService.getServiceStartedAssertingMessageProcessor()
           
 

Methods in org.mule.service that return types with arguments of type MessageProcessor
 List<MessageProcessor> ServiceCompositeMessageSource.getMessageProcessors()
           
 

Methods in org.mule.service with parameters of type MessageProcessor
 void ServiceCompositeMessageSource.addMessageProcessor(MessageProcessor processor)
           
 void ServiceCompositeMessageSource.setCatchAllStrategy(MessageProcessor catchAllStrategy)
           
 void AbstractService.setMessageProcessor(MessageProcessor processor)
          Deprecated. 
 void AbstractService.setOutboundMessageProcessor(MessageProcessor processor)
           
 

Method parameters in org.mule.service with type arguments of type MessageProcessor
 void ServiceCompositeMessageSource.setMessageProcessors(List<MessageProcessor> processors)
           
 

Uses of MessageProcessor in org.mule.service.processor
 

Classes in org.mule.service.processor that implement MessageProcessor
 class ServiceAsyncRequestReplyRequestor
           
 class ServiceInternalMessageProcessor
           
 class ServiceLoggingMessageProcessor
           
 class ServiceOutboundMessageProcessor
          Responsible for determining if the Service outbound phase should be used and making a copy of the event to use.
 class ServiceOutboundStatisticsMessageProcessor
           
 class ServiceSetEventRequestContextMessageProcessor
           
 class ServiceStatisticsMessageProcessor
           
 

Uses of MessageProcessor in org.mule.source
 

Fields in org.mule.source declared as MessageProcessor
protected  MessageProcessor StartableCompositeMessageSource.listener
           
 

Methods in org.mule.source with parameters of type MessageProcessor
 void StartableCompositeMessageSource.setListener(MessageProcessor listener)
           
 void ClusterizableMessageSourceWrapper.setListener(MessageProcessor listener)
           
 

Uses of MessageProcessor in org.mule.tck.functional
 

Classes in org.mule.tck.functional that implement MessageProcessor
 class AssertionMessageProcessor
           
 class StringAppendTestTransformer
           
 

Uses of MessageProcessor in org.mule.tck.transformer
 

Classes in org.mule.tck.transformer that implement MessageProcessor
 class NoActionTransformer
          NoActionTransformer doesn't do any transformation on the source object and returns the source as the result.
 class ValidateResponse
          Throws an exception if the message does not contain "success".
 

Uses of MessageProcessor in org.mule.transformer
 

Classes in org.mule.transformer that implement MessageProcessor
 class AbstractDiscoverableTransformer
           
 class AbstractMessageAwareTransformer
          Deprecated.  
 class AbstractMessageTransformer
          AbstractMessageTransformer is a transformer that has a reference to the current message.
 class AbstractTransformer
          AbstractTransformer is a base class for all transformers.
 class CompositeConverter
          Composes many converters to behave as a single one.
 class TransformerChain
          A referencable chain of transformers that can be used as a single transformer
 class TransformerTemplate
          TODO
 

Uses of MessageProcessor in org.mule.transformer.codec
 

Classes in org.mule.transformer.codec that implement MessageProcessor
 class Base64Decoder
          Base64Encoder transforms Base64 encoded data into strings or byte arrays.
 class Base64Encoder
          Base64Encoder transforms strings or byte arrays into Base64 encoded string.
 class XmlEntityDecoder
          Decodes a String or byte[] containing XML entities
 class XmlEntityEncoder
          Encodes a string with XML entities
 

Uses of MessageProcessor in org.mule.transformer.compression
 

Classes in org.mule.transformer.compression that implement MessageProcessor
 class AbstractCompressionTransformer
          AbstractCompressionTransformer is a base class for all transformers that can compress or uncompress data when they performa message transformation.
 class GZipCompressTransformer
          GZipCompressTransformer is a transformer compressing objects into byte arrays.
 class GZipUncompressTransformer
          GZipCompressTransformer will uncompress a byte[] or InputStream
 

Uses of MessageProcessor in org.mule.transformer.encryption
 

Classes in org.mule.transformer.encryption that implement MessageProcessor
 class AbstractEncryptionTransformer
          EncryptionTransformer will transform an array of bytes or string into an encrypted array of bytes
 class DecryptionTransformer
          EncryptionTransformer will transform an encrypted array of bytes or string into an decrypted array of bytes
 class EncryptionTransformer
          EncryptionTransformer will transform an array of bytes or string into an encrypted array of bytes
 

Uses of MessageProcessor in org.mule.transformer.simple
 

Classes in org.mule.transformer.simple that implement MessageProcessor
 class AbstractAddVariablePropertyTransformer
           
 class AbstractRemoveVariablePropertyTransformer
           
 class AddAttachmentTransformer
           
 class AddFlowVariableTransformer
           
 class AddPropertyTransformer
           
 class AddSessionVariableTransformer
           
 class AutoTransformer
          A transformer that uses the transform discovery mechanism to convert the message payload.
 class BeanToMap
          Conversts a simple bean object to a Map.
 class ByteArrayToHexString
          Converts a Byte array to a Hex String.
 class ByteArrayToMuleMessage
          TODO
 class ByteArrayToObject
          ByteArrayToObject works in the same way as ByteArrayToSerializable but checks if the byte array is a serialised object and if not will return a String created from the bytes as the returnType on the transformer.
 class ByteArrayToSerializable
          ByteArrayToSerializable converts a serialized object to its object representation
 class CombineCollectionsTransformer
          Takes a payload which is a Collection of Collections and turns into a single List.
 class CopyAttachmentsTransformer
           
 class CopyPropertiesTransformer
           
 class DataHandlerToInputStreamTransformer
           
 class GetBeanProperty
          Looks up a property from a JavaBean using PropertyUtils.getProperty().
 class HexStringToByteArray
          Converts a Hex String to a Byte array
 class MapLookup
          MapLookup looks up and returns an object from a Map based on a key.
 class MapToBean
          Creates and object of type AbstractTransformer.getReturnClass() and populates values of a Map as bean properties on the object.
 class MessagePropertiesTransformer
           A configurable message transformer that allows users to add, overwrite, rename and delete properties on the current message.
 class MuleMessageToByteArray
          TODO
 class NumberToString
          NumberToString converts a Number to a String.
 class ObjectArrayToString
          ObjectArrayToString transformer is the opposite of StringToObjectArray - it simply converts Object[] to a String in which each element is separated by a configurable delimiter (default is a space).
 class ObjectToByteArray
          ObjectToByteArray converts serilaizable object to a byte array but treats java.lang.String differently by converting to bytes using the String.getBytrs() method.
 class ObjectToInputStream
          ObjectToInputStream converts Serializable objects to an InputStream but treats java.lang.String, byte[] and org.mule.api.transport.OutputHandler differently by using their byte[] content rather thqn Serializing them.
 class ObjectToOutputHandler
          ObjectToOutputHandler converts a byte array into a String.
 class ObjectToString
          ObjectToString transformer is useful for debugging.
 class ParseTemplateTransformer
          Loads a template and parses its content to resolve expressions.
 class PropertyEditorTextToValueTransformer
          PropertyEditorTextToValueTransformer adapts a PropertyEditor instance allowing it to be used to transform from a String to another type in Mule
 class PropertyEditorValueToTextTransformer
          PropertyEditorValueToTextTransformer adapts a PropertyEditor instance allowing it to be used to transform from a specific type to a String.
 class RemoveAttachmentTransformer
           
 class RemoveFlowVariableTransformer
           
 class RemovePropertyTransformer
           
 class RemoveSessionVariableTransformer
           
 class SerializableToByteArray
          SerializableToByteArray converts a serializable object or a String to a byte array.
 class SetPayloadTransformer
          Transformer that modifies the payload of the message according to the provided value.
 class StringAppendTransformer
           
 class StringToBoolean
          ByteArrayToSerializable converts a serialized object to its object representation
 class StringToNumber
          StringToNumber converts a String to a Number.
 class StringToObjectArray
          StringToObjectArray converts a String into an object array.
 

Uses of MessageProcessor in org.mule.transport
 

Classes in org.mule.transport that implement MessageProcessor
 class AbstractMessageDispatcher
          Abstract implementation of an outbound channel adaptors.
 class UnsupportedMessageDispatcher
           
 

Fields in org.mule.transport declared as MessageProcessor
protected  MessageProcessor AbstractMessageReceiver.listener
          MessageProcessor chain used to process messages once the transport specific MessageReceiver has received transport message and created the MuleEvent
 

Methods in org.mule.transport that return MessageProcessor
 MessageProcessor AbstractConnector.createDispatcherMessageProcessor(OutboundEndpoint endpoint)
           
 

Methods in org.mule.transport with parameters of type MessageProcessor
 void AbstractConnector.registerListener(InboundEndpoint endpoint, MessageProcessor messageProcessorChain, FlowConstruct flowConstruct)
           
 void AbstractMessageReceiver.setListener(MessageProcessor processor)
           
 

Uses of MessageProcessor in org.mule.transport.ajax
 

Classes in org.mule.transport.ajax that implement MessageProcessor
 class AjaxMessageDispatcher
          Will dispatch Mule events to ajax clients available in Bayeux that are listening to this endpoint.
 

Uses of MessageProcessor in org.mule.transport.ejb
 

Classes in org.mule.transport.ejb that implement MessageProcessor
 class EjbMessageDispatcher
          Invokes a method on an EJB object stored in Jndi.
 

Uses of MessageProcessor in org.mule.transport.email
 

Classes in org.mule.transport.email that implement MessageProcessor
 class SmtpMessageDispatcher
          SmtpMessageDispatcher will dispatch Mule events as Mime email messages over an SMTP gateway.
 

Uses of MessageProcessor in org.mule.transport.email.transformers
 

Classes in org.mule.transport.email.transformers that implement MessageProcessor
 class EmailMessageToString
          EmailMessageToString extracts the text body of java mail Message and returns a string.
 class MimeMessageToRfc822ByteArray
           
 class ObjectToMimeMessage
          Transforms a Message to a MuleMessage, with support for attachments
 class Rfc822ByteArraytoMimeMessage
           
 class StringToEmailMessage
          StringToEmailMessage will convert a String to a JavaMail Message, using the String as the contents.
 

Uses of MessageProcessor in org.mule.transport.file
 

Classes in org.mule.transport.file that implement MessageProcessor
 class FileMessageDispatcher
          FileMessageDispatcher is used to read/write files to the filesystem
 

Uses of MessageProcessor in org.mule.transport.file.transformers
 

Classes in org.mule.transport.file.transformers that implement MessageProcessor
 class FileToByteArray
          FileToByteArray reads the contents of a file as a byte array.
 class FileToString
          FileToString reads file contents into a string.
 

Uses of MessageProcessor in org.mule.transport.ftp
 

Classes in org.mule.transport.ftp that implement MessageProcessor
 class FtpMessageDispatcher
           
 

Uses of MessageProcessor in org.mule.transport.http
 

Classes in org.mule.transport.http that implement MessageProcessor
 class HttpClientMessageDispatcher
          HttpClientMessageDispatcher dispatches Mule events over HTTP.
 class HttpsClientMessageDispatcher
           
 

Methods in org.mule.transport.http with parameters of type MessageProcessor
 void HttpConnector.registerListener(InboundEndpoint endpoint, MessageProcessor listener, FlowConstruct flowConstruct)
           
 

Uses of MessageProcessor in org.mule.transport.http.components
 

Classes in org.mule.transport.http.components that implement MessageProcessor
 class HttpResponseBuilder
           
 class RestServiceWrapper
          This service can used to proxy REST style services as local Mule Components.
 class StaticResourceMessageProcessor
          A MessageProcessor that can be used by HTTP endpoints to serve static files from a directory on the filesystem.
 

Methods in org.mule.transport.http.components that return types with arguments of type MessageProcessor
protected  List<MessageProcessor> HttpResponseBuilder.getOwnedMessageProcessors()
           
 

Methods in org.mule.transport.http.components with parameters of type MessageProcessor
 void HttpResponseBuilder.setMessageProcessor(MessageProcessor messageProcessor)
           
 

Uses of MessageProcessor in org.mule.transport.http.config.spring.factories
 

Methods in org.mule.transport.http.config.spring.factories with parameters of type MessageProcessor
 void HttpProxyFactoryBean.setMessageProcessor(MessageProcessor processor)
           
 

Uses of MessageProcessor in org.mule.transport.http.construct
 

Constructor parameters in org.mule.transport.http.construct with type arguments of type MessageProcessor
HttpProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, CachingStrategy cachingStrategy)
           
HttpProxy(String name, MuleContext muleContext, MessageSource messageSource, OutboundEndpoint outboundEndpoint, List<MessageProcessor> transformers, List<MessageProcessor> responseTransformers, CachingStrategy cachingStrategy)
           
 

Uses of MessageProcessor in org.mule.transport.http.servlet
 

Classes in org.mule.transport.http.servlet that implement MessageProcessor
 class ServletTransformer
          THIS CLASS IS UNSUPPORTED AND THE IMPLEMENTATION DOES NOT CONFORM TO THE SERVLET SPECIFICATION! With that said, it can be used to make integration with libraries that only support servlets easier.
 

Uses of MessageProcessor in org.mule.transport.http.transformers
 

Classes in org.mule.transport.http.transformers that implement MessageProcessor
 class FormTransformer
          Converts HTML forms POSTs into a Map of parameters.
 class HttpClientMethodResponseToObject
          HttpClientMethodResponseToObject transforms a http client response to a DefaultMuleMessage.
 class HttpRequestBodyToParamMap
           
 class HttpResponseToString
          Converts an Http Response object to String.
 class MuleMessageToHttpResponse
          Converts a MuleMessage into an Http response.
 class ObjectToHttpClientMethodRequest
          ObjectToHttpClientMethodRequest transforms a MuleMessage into a HttpClient HttpMethod that represents an HttpRequest.
 class ServletRequestToOutputHandler
          Adds support for converting a HttpServletRequest into an OutputHandler
 

Uses of MessageProcessor in org.mule.transport.jdbc
 

Classes in org.mule.transport.jdbc that implement MessageProcessor
 class JdbcMessageDispatcher
          The Jdbc Message dispatcher is responsible for executing SQL queries against a database.
 

Uses of MessageProcessor in org.mule.transport.jms
 

Classes in org.mule.transport.jms that implement MessageProcessor
 class JmsMessageDispatcher
          JmsMessageDispatcher is responsible for dispatching messages to JMS destinations.
 

Uses of MessageProcessor in org.mule.transport.jms.transformers
 

Classes in org.mule.transport.jms.transformers that implement MessageProcessor
 class AbstractJmsTransformer
          AbstractJmsTransformer is an abstract class that should be used for all transformers where a JMS message will be the transformed or transformee object.
 class JMSMessageToObject
          JMSMessageToObject Will convert a javax.jms.Message or sub-type into an object by extracting the message payload.
 class ObjectToJMSMessage
          ObjectToJMSMessage will convert any object to a javax.jms.Message or sub-type into an object.
 

Uses of MessageProcessor in org.mule.transport.polling
 

Fields in org.mule.transport.polling declared as MessageProcessor
protected  MessageProcessor MessageProcessorPollingMessageReceiver.sourceMessageProcessor
           
 

Uses of MessageProcessor in org.mule.transport.quartz
 

Classes in org.mule.transport.quartz that implement MessageProcessor
 class QuartzMessageDispatcher
          Can schedule a Job with the Quartz scheduler.
 

Uses of MessageProcessor in org.mule.transport.rmi
 

Classes in org.mule.transport.rmi that implement MessageProcessor
 class RmiMessageDispatcher
          RmiMessageDispatcher will send transformed mule events over RMI-JRMP.
 

Uses of MessageProcessor in org.mule.transport.servlet.transformers
 

Classes in org.mule.transport.servlet.transformers that implement MessageProcessor
 class HttpRequestToByteArray
          Converts an HttpServletRequest into an array of bytes by extracting the payload of the request.
 class HttpRequestToInputStream
          Converts a HttpServletRequest into an InputStream.
 class HttpRequestToParameter
           
 class HttpRequestToParameterMap
          Returns a simple Map of the parameters sent with the HTTP Request.
 

Uses of MessageProcessor in org.mule.transport.sftp
 

Classes in org.mule.transport.sftp that implement MessageProcessor
 class SftpMessageDispatcher
          SftpMessageDispatcher dispatches files via sftp to a remote sftp service.
 

Uses of MessageProcessor in org.mule.transport.sftp.transformers
 

Classes in org.mule.transport.sftp.transformers that implement MessageProcessor
 class InputStreamToByteArray
          TODO
 

Uses of MessageProcessor in org.mule.transport.soap.axis
 

Classes in org.mule.transport.soap.axis that implement MessageProcessor
 class AxisMessageDispatcher
          AxisMessageDispatcher is used to make soap requests via the Axis soap client.
 

Uses of MessageProcessor in org.mule.transport.soap.axis.wsdl
 

Classes in org.mule.transport.soap.axis.wsdl that implement MessageProcessor
 class AxisWsdlMessageDispatcher
          Creates and Axis client services from WSDL and invokes it.
 

Uses of MessageProcessor in org.mule.transport.stdio
 

Classes in org.mule.transport.stdio that implement MessageProcessor
 class StdioMessageDispatcher
          StdioMessageDispatcher is a simple stream dispatcher that obtains a stream from the Stream Connector to write to.
 

Methods in org.mule.transport.stdio with parameters of type MessageProcessor
 void StdioConnector.registerListener(InboundEndpoint endpoint, MessageProcessor listener, FlowConstruct flowConstruct)
           
 

Uses of MessageProcessor in org.mule.transport.tcp
 

Classes in org.mule.transport.tcp that implement MessageProcessor
 class LocalSocketTcpMessageDispatcher
          LocalSocketTcpMessageDispatcher will send transformed Mule events over TCP.
 class TcpMessageDispatcher
          Send transformed Mule events over TCP.
 

Uses of MessageProcessor in org.mule.transport.udp
 

Classes in org.mule.transport.udp that implement MessageProcessor
 class UdpMessageDispatcher
          UdpMessageDispatcher is responsible for dispatching MuleEvents as UDP packets on the network
 

Uses of MessageProcessor in org.mule.transport.vm
 

Classes in org.mule.transport.vm that implement MessageProcessor
 class VMMessageDispatcher
          VMMessageDispatcher is used for providing in memory interaction between components.
 

Uses of MessageProcessor in org.mule.transport.xmpp
 

Classes in org.mule.transport.xmpp that implement MessageProcessor
 class XmppMessageDispatcher
          Allows Mule events to be sent over Xmpp
 

Uses of MessageProcessor in org.mule.transport.xmpp.transformers
 

Classes in org.mule.transport.xmpp.transformers that implement MessageProcessor
 class ObjectToXmppPacket
          Creates an Xmpp message packet from a MuleMessage
 class XmppPacketToObject
           
 



Copyright © 2003-2012 MuleSoft, Inc.. All Rights Reserved.