A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _

A

AbderaFactory - Class in org.mule.module.atom
Adds an instance of the factory to the registry so that folks can have the Factory injected into their components
AbderaFactory() - Constructor for class org.mule.module.atom.AbderaFactory
 
AbderaServiceComponent - Class in org.mule.module.atom
This component receives requests from Mule and passes them off to Abdera.
AbderaServiceComponent() - Constructor for class org.mule.module.atom.AbderaServiceComponent
 
AbderaServiceComponent.AbderaCallable - Class in org.mule.module.atom
 
AbderaServiceComponent.AbderaCallable(AbderaServiceComponent) - Constructor for class org.mule.module.atom.AbderaServiceComponent.AbderaCallable
 
abort() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Abort if authentication fails
abortProcess(Object) - Method in interface org.mule.module.bpm.BPMS
Abort a running process (end abnormally).
abortProcess(Object) - Method in class org.mule.module.jbpm.Jbpm
Delete a process instance.
absoluteResourcePaths - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
AbstractAddVariablePropertyTransformer - Class in org.mule.transformer.simple
 
AbstractAddVariablePropertyTransformer() - Constructor for class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
AbstractAgent - Class in org.mule
Implements common methods for all Agents.
AbstractAgent(String) - Constructor for class org.mule.AbstractAgent
 
AbstractAggregator - Class in org.mule.routing
AbstractEventAggregator will aggregate a set of messages into a single message.
AbstractAggregator() - Constructor for class org.mule.routing.AbstractAggregator
 
AbstractAnnotatedTransformerArgumentResolver - Class in org.mule.config.transformer
An abstract resolver that can be extend to resolve/create an object based on Annotated classes.
AbstractAnnotatedTransformerArgumentResolver() - Constructor for class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
AbstractAnnotationConfigurationBuilder - Class in org.mule.module.ibeans.config
Provides implementation support for configuration builders that configure Mule by scanning annotations on the classpath.
AbstractAnnotationConfigurationBuilder() - Constructor for class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
AbstractAnnotationConfigurationBuilder(String...) - Constructor for class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
AbstractAnnotationConfigurationBuilder(ClassLoader) - Constructor for class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
AbstractAnnotationConfigurationBuilder(ClassLoader, String...) - Constructor for class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
AbstractArgumentEntryPointResolver - Class in org.mule.model.resolvers
A base class that allows implementing resolvers to define what parameters it is expecting.
AbstractArgumentEntryPointResolver() - Constructor for class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
AbstractAsynchronousLoanBrokerTestCase - Class in org.mule.example.loanbroker.tests
Tests the Loan Broker application asynchronously.
AbstractAsynchronousLoanBrokerTestCase() - Constructor for class org.mule.example.loanbroker.tests.AbstractAsynchronousLoanBrokerTestCase
 
AbstractAsyncRequestReplyRequester - Class in org.mule.routing.requestreply
 
AbstractAsyncRequestReplyRequester() - Constructor for class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
AbstractAuthenticationFilter - Class in org.mule.security
AbstractEndpointSecurityFilter provides a framework to perform inbound or outbound authentication for messages.
AbstractAuthenticationFilter() - Constructor for class org.mule.security.AbstractAuthenticationFilter
 
AbstractByteProtocol - Class in org.mule.transport.tcp.protocols
This Abstract class has been introduced so as to have the byte protocols (i.e.
AbstractByteProtocol(boolean) - Constructor for class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
AbstractCatchAllStrategy - Class in org.mule.routing
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.
AbstractCatchAllStrategy() - Constructor for class org.mule.routing.AbstractCatchAllStrategy
 
AbstractChildDefinitionParser - Class in org.mule.config.spring.parsers
This definition parser supports the definition of beans that are then set on the parent bean - it extends AbstractHierarchicalDefinitionParser with methods that assume the data are associated with a single property.
AbstractChildDefinitionParser() - Constructor for class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
AbstractChildElementIterator - Class in org.mule.config.spring.parsers.processors
This iterates over child elements, parsing them and calling AbstractChildElementIterator.insertBean(BeanAssembler, Object, Element, Element).
AbstractChildElementIterator(BeanAssemblerFactory, PropertyConfiguration) - Constructor for class org.mule.config.spring.parsers.processors.AbstractChildElementIterator
 
AbstractClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
An abstract builder for non proxy clients.
AbstractClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
AbstractComponent - Class in org.mule.component
Abstract Component to be used by all Component implementations.
AbstractComponent() - Constructor for class org.mule.component.AbstractComponent
 
AbstractCompressionTransformer - Class in org.mule.transformer.compression
AbstractCompressionTransformer is a base class for all transformers that can compress or uncompress data when they performa message transformation.
AbstractCompressionTransformer() - Constructor for class org.mule.transformer.compression.AbstractCompressionTransformer
default constructor required for discovery
AbstractConfigBuilderTestCase - Class in org.mule.tck
 
AbstractConfigBuilderTestCase(boolean) - Constructor for class org.mule.tck.AbstractConfigBuilderTestCase
 
AbstractConfigurationBuilder - Class in org.mule.config.builders
A support class for ConfigurationBuilder implementations that handles the logic of creating config arrays and Properties arguments
AbstractConfigurationBuilder() - Constructor for class org.mule.config.builders.AbstractConfigurationBuilder
 
AbstractConfigurationPattern - Class in org.mule.construct
A template class for configuration patterns, which takes care of setting common message processors and optional transformers defined on the pattern.
AbstractConfigurationPattern(String, MuleContext, List<MessageProcessor>, List<MessageProcessor>) - Constructor for class org.mule.construct.AbstractConfigurationPattern
 
AbstractConnector - Class in org.mule.transport
AbstractConnector provides base functionality for all connectors provided with Mule.
AbstractConnector(MuleContext) - Constructor for class org.mule.transport.AbstractConnector
 
AbstractConnectorHolder<S extends Servlet,R extends MessageReceiver> - Class in org.mule.transport.servlet.jetty
TODO
AbstractConnectorHolder(Connector, S, R) - Constructor for class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
AbstractCorrelationAggregator - Class in org.mule.routing
AbstractCorrelationAggregatingMessageProcessor uses the CorrelationID and CorrelationGroupSize properties of the MuleMessage to manage message groups.
AbstractCorrelationAggregator() - Constructor for class org.mule.routing.AbstractCorrelationAggregator
 
AbstractCounter - Class in org.mule.util.counters.impl
 
AbstractCounter(String, CounterFactory.Type) - Constructor for class org.mule.util.counters.impl.AbstractCounter
 
AbstractDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
AbstractDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
AbstractDelegatingDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This allows a definition parsers to be dynamically represented by different definition parsers, depending on the context.
AbstractDelegatingDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
AbstractDelegatingDefinitionParser(MuleDefinitionParser[]) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
AbstractDeploymentListener - Class in org.mule.module.launcher
Convenience implementation of DeploymentListener.
AbstractDeploymentListener() - Constructor for class org.mule.module.launcher.AbstractDeploymentListener
 
AbstractDiscoverableTransformer - Class in org.mule.transformer
 
AbstractDiscoverableTransformer() - Constructor for class org.mule.transformer.AbstractDiscoverableTransformer
 
AbstractDynamicMessageProcessor - Class in org.mule.processor
Implementation of MessageProcessor that dynamically chooses and uses another MessageProcessor
AbstractDynamicMessageProcessor() - Constructor for class org.mule.processor.AbstractDynamicMessageProcessor
 
AbstractEncryptionTransformer - Class in org.mule.transformer.encryption
EncryptionTransformer will transform an array of bytes or string into an encrypted array of bytes
AbstractEncryptionTransformer() - Constructor for class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
AbstractEndpoint - Class in org.mule.endpoint
ImmutableMuleEndpoint describes a Provider in the Mule Server.
AbstractEndpoint(Connector, EndpointURI, String, Map, TransactionConfig, boolean, MessageExchangePattern, int, String, String, String, MuleContext, RetryPolicyTemplate, AbstractRedeliveryPolicy, EndpointMessageProcessorChainFactory, List<MessageProcessor>, List<MessageProcessor>, boolean, String) - Constructor for class org.mule.endpoint.AbstractEndpoint
 
AbstractEndpointAnnotationParser - Class in org.mule.config.endpoint
TODO
AbstractEndpointAnnotationParser() - Constructor for class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
AbstractEndpointBuilder - Class in org.mule.endpoint
Abstract endpoint builder used for externalizing the complex creation logic of endpoints out of the endpoint instance itself.
AbstractEndpointBuilder() - Constructor for class org.mule.endpoint.AbstractEndpointBuilder
 
AbstractEndpointFactoryBean - Class in org.mule.config.spring.factories
Abstract spring FactoryBean used to creating endpoints via spring.
AbstractEndpointFactoryBean(EndpointURIEndpointBuilder) - Constructor for class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
AbstractEndpointFactoryBean() - Constructor for class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
AbstractEndpointSecurityFilter - Class in org.mule.security
Deprecated. 
AbstractEndpointSecurityFilter() - Constructor for class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.  
AbstractEndpointURIBuilder - Class in org.mule.endpoint
UrlEndpointURIBuilder is the default endpointUri strategy suitable for most connectors
AbstractEndpointURIBuilder() - Constructor for class org.mule.endpoint.AbstractEndpointURIBuilder
 
AbstractEntryPointResolver - Class in org.mule.model.resolvers
A Base class for EntryPointResolver.
AbstractEntryPointResolver() - Constructor for class org.mule.model.resolvers.AbstractEntryPointResolver
 
AbstractEnvelopeInterceptor - Class in org.mule.interceptor
EnvelopeInterceptor is an intercepter that will fire before and after an event is received.
AbstractEnvelopeInterceptor() - Constructor for class org.mule.interceptor.AbstractEnvelopeInterceptor
 
AbstractExceptionHandler - Class in org.mule.example.errorhandler
AbstractExceptionListener TODO (document class)
AbstractExceptionHandler() - Constructor for class org.mule.example.errorhandler.AbstractExceptionHandler
 
AbstractExceptionListener - Class in org.mule.exception
This is the base class for exception strategies which contains several helper methods.
AbstractExceptionListener() - Constructor for class org.mule.exception.AbstractExceptionListener
 
AbstractExceptionStrategy - Class in org.mule.exception
Deprecated. use AbstractExceptionListener
AbstractExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractExceptionStrategy
Deprecated.  
AbstractExpressionTransformer - Class in org.mule.expression.transformers
This transformer will evaluate one or more expressions on the current message and return the results as an Array.
AbstractExpressionTransformer() - Constructor for class org.mule.expression.transformers.AbstractExpressionTransformer
 
AbstractFileWatcher - Class in org.mule.module.launcher
 
AbstractFileWatcher(File) - Constructor for class org.mule.module.launcher.AbstractFileWatcher
 
AbstractFileWatcher(Collection<File>) - Constructor for class org.mule.module.launcher.AbstractFileWatcher
 
AbstractFilterCollection - Class in org.mule.routing.filters.logic
Manages a filter collection.
AbstractFilterCollection() - Constructor for class org.mule.routing.filters.logic.AbstractFilterCollection
 
AbstractFilterCollection(List<Filter>) - Constructor for class org.mule.routing.filters.logic.AbstractFilterCollection
 
AbstractFilterCollection(Filter...) - Constructor for class org.mule.routing.filters.logic.AbstractFilterCollection
 
AbstractFilteringMessageProcessor - Class in org.mule.processor
Abstract InterceptingMessageProcessor that can be easily be extended and used for filtering message flow through a MessageProcessor chain.
AbstractFilteringMessageProcessor() - Constructor for class org.mule.processor.AbstractFilteringMessageProcessor
 
AbstractFirstResultSerialDefinitionParser - Class in org.mule.config.spring.parsers.delegate
Extend AbstractSerialDelegatingDefinitionParser to return the first definition as the final result
AbstractFirstResultSerialDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractFirstResultSerialDefinitionParser
 
AbstractFirstResultSerialDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractFirstResultSerialDefinitionParser
 
AbstractFlowConstruct - Class in org.mule.construct
Abstract implementation of FlowConstruct that: Is constructed with unique name and MuleContext.
AbstractFlowConstruct(String, MuleContext) - Constructor for class org.mule.construct.AbstractFlowConstruct
 
AbstractFlowConstructBuilder<T extends AbstractFlowConstructBuilder<?,?>,F extends AbstractFlowConstruct> - Class in org.mule.construct.builder
 
AbstractFlowConstructBuilder() - Constructor for class org.mule.construct.builder.AbstractFlowConstructBuilder
 
AbstractFlowConstructDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
AbstractFlowConstructDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
AbstractFlowConstructFactoryBean - Class in org.mule.config.spring.factories
 
AbstractFlowConstructFactoryBean() - Constructor for class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
AbstractFlowConstructStatistics - Class in org.mule.management.stats
Statistics common to flows and services
AbstractFlowConstructStatistics(String, String) - Constructor for class org.mule.management.stats.AbstractFlowConstructStatistics
 
AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder<T extends AbstractFlowConstructBuilder<?,?>,F extends AbstractFlowConstruct> - Class in org.mule.construct.builder
 
AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder() - Constructor for class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
AbstractFlowConstructWithSingleInboundEndpointBuilder<T extends AbstractFlowConstructBuilder<?,?>,F extends AbstractFlowConstruct> - Class in org.mule.construct.builder
 
AbstractFlowConstructWithSingleInboundEndpointBuilder() - Constructor for class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
AbstractHierarchicalDefinitionParser - Class in org.mule.config.spring.parsers
This definition parser introduces the notion of Hierarchical processing to nested XML elements.
AbstractHierarchicalDefinitionParser() - Constructor for class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
AbstractHostPortDatabaseDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
AbstractHostPortDatabaseDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
AbstractInboundMessageProcessorBuilder - Class in org.mule.module.cxf.builder
An abstract builder for CXF services.
AbstractInboundMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
AbstractInterceptingMessageProcessor - Class in org.mule.processor
Abstract implementation of InterceptingMessageProcessor that simply provides an implementation of setNext and holds the next message processor as an attribute.
AbstractInterceptingMessageProcessor() - Constructor for class org.mule.processor.AbstractInterceptingMessageProcessor
 
AbstractInterceptingMessageProcessorBase - Class in org.mule.processor
Abstract implementation that provides the infrastructure for intercepting message processors.
AbstractInterceptingMessageProcessorBase() - Constructor for class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
AbstractJavaComponent - Class in org.mule.component
Abstract implementation of JavaComponent adds JavaComponent specifics like EntryPointResolverSet and ObjectFactory.
AbstractJavaComponent() - Constructor for class org.mule.component.AbstractJavaComponent
For Spring only
AbstractJavaComponent(ObjectFactory) - Constructor for class org.mule.component.AbstractJavaComponent
 
AbstractJavaComponent(ObjectFactory, EntryPointResolverSet, List<InterfaceBinding>) - Constructor for class org.mule.component.AbstractJavaComponent
 
AbstractJaxpFilter - Class in org.mule.module.xml.filters
Common filter functionality for filters which need to convert payloads to Documents.
AbstractJaxpFilter() - Constructor for class org.mule.module.xml.filters.AbstractJaxpFilter
 
AbstractJCEEncryptionStrategy - Class in org.mule.security
A JCE based encryption strategy.
AbstractJCEEncryptionStrategy() - Constructor for class org.mule.security.AbstractJCEEncryptionStrategy
 
AbstractJmsTransformer - Class in org.mule.transport.jms.transformers
AbstractJmsTransformer is an abstract class that should be used for all transformers where a JMS message will be the transformed or transformee object.
AbstractJmsTransformer() - Constructor for class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
AbstractJmxSupport - Class in org.mule.module.management.support
 
AbstractJmxSupport() - Constructor for class org.mule.module.management.support.AbstractJmxSupport
 
AbstractJndiConnector - Class in org.mule.transport
This class acts as common baseclass for both Rmi & EjbConnector Resolves Jndi root for connector usage
AbstractJndiConnector(MuleContext) - Constructor for class org.mule.transport.AbstractJndiConnector
 
AbstractJndiNameResolver - Class in org.mule.transport.jms.jndi
 
AbstractJndiNameResolver() - Constructor for class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
AbstractJob - Class in org.mule.transport.quartz.jobs
A superclass for Quartz jobs.
AbstractJob() - Constructor for class org.mule.transport.quartz.jobs.AbstractJob
 
AbstractJobConfig - Class in org.mule.transport.quartz.config
Base implementation of JobConfig.
AbstractJobConfig() - Constructor for class org.mule.transport.quartz.config.AbstractJobConfig
 
AbstractJsonTransformer - Class in org.mule.module.json.transformers
TODO
AbstractJsonTransformer() - Constructor for class org.mule.module.json.transformers.AbstractJsonTransformer
 
AbstractLifecycleManager<O> - Class in org.mule.lifecycle
This is a base implementation of the LifecycleManager interface and provides almost all the plumbing required to write a LifecycleManager implementation.
AbstractLifecycleManager(String, O) - Constructor for class org.mule.lifecycle.AbstractLifecycleManager
 
AbstractLoanBroker - Class in org.mule.example.loanbroker
LoanBroker is the Service that starts the loan request process.
AbstractLoanBroker() - Constructor for class org.mule.example.loanbroker.AbstractLoanBroker
 
AbstractLoanBrokerApp - Class in org.mule.example.loanbroker
Runs the LoanBroker example application.
AbstractLoanBrokerApp() - Constructor for class org.mule.example.loanbroker.AbstractLoanBrokerApp
 
AbstractLoanBrokerApp(String) - Constructor for class org.mule.example.loanbroker.AbstractLoanBrokerApp
 
AbstractLoanBrokerTestCase - Class in org.mule.example.loanbroker.tests
 
AbstractLoanBrokerTestCase() - Constructor for class org.mule.example.loanbroker.tests.AbstractLoanBrokerTestCase
 
AbstractMailConnector - Class in org.mule.transport.email
Abstract superclass for mail connectors.
AbstractMailConnector(int, String, MuleContext) - Constructor for class org.mule.transport.email.AbstractMailConnector
 
AbstractMailFilter - Class in org.mule.transport.email.filters
AbstractMailFilter is a base class for all javax.mail.Message filters.
AbstractMailFilter() - Constructor for class org.mule.transport.email.filters.AbstractMailFilter
 
AbstractMapBeanAssembler - Class in org.mule.config.spring.parsers.assembly
 
AbstractMapBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Constructor for class org.mule.config.spring.parsers.assembly.AbstractMapBeanAssembler
 
AbstractMapContext<K,V> - Class in org.mule.el.context
 
AbstractMapContext() - Constructor for class org.mule.el.context.AbstractMapContext
 
AbstractMatchingRouter - Class in org.mule.routing
AbstractRouterCollection provides common method implementations of router collections for in and outbound routers.
AbstractMatchingRouter() - Constructor for class org.mule.routing.AbstractMatchingRouter
 
AbstractMessageAwareTransformer - Class in org.mule.transformer
Deprecated.  
AbstractMessageAwareTransformer() - Constructor for class org.mule.transformer.AbstractMessageAwareTransformer
Deprecated.  
AbstractMessageDispatcher - Class in org.mule.transport
Abstract implementation of an outbound channel adaptors.
AbstractMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.AbstractMessageDispatcher
 
AbstractMessageDispatcherFactory - Class in org.mule.transport
AbstractMessageDispatcherFactory is a base implementation of the MessageDispatcherFactory interface for managing the lifecycle of message dispatchers.
AbstractMessageDispatcherFactory() - Constructor for class org.mule.transport.AbstractMessageDispatcherFactory
 
AbstractMessageProcessorChain - Class in org.mule.processor.chain
Builder needs to return a composite rather than the first MessageProcessor in the chain.
AbstractMessageProcessorChain(String, List<MessageProcessor>) - Constructor for class org.mule.processor.chain.AbstractMessageProcessorChain
 
AbstractMessageProcessorChainBuilder - Class in org.mule.processor.chain
Constructs a chain of MessageProcessors and wraps the invocation of the chain in a composite MessageProcessor.
AbstractMessageProcessorChainBuilder() - Constructor for class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
AbstractMessageProcessorChainBuilder(FlowConstruct) - Constructor for class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
AbstractMessageProcessorOwner - Class in org.mule.processor
An object that owns message processors and delegates startup/shutdown events to them.
AbstractMessageProcessorOwner() - Constructor for class org.mule.processor.AbstractMessageProcessorOwner
 
AbstractMessageReceiver - Class in org.mule.transport
AbstractMessageReceiver provides common methods for all Message Receivers provided with Mule.
AbstractMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.AbstractMessageReceiver
Creates the Message Receiver
AbstractMessageRequester - Class in org.mule.transport
The Message Requester is used to explicitly request messages from a message channel or resource rather than subscribing to inbound events or polling for messages.
AbstractMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.AbstractMessageRequester
 
AbstractMessageRequesterFactory - Class in org.mule.transport
A base implementation of the MessageRequesterFactory interface for managing the lifecycle of message requesters.
AbstractMessageRequesterFactory() - Constructor for class org.mule.transport.AbstractMessageRequesterFactory
 
AbstractMessageSequence<PayloadType> - Class in org.mule.routing
An abstract implementation of a MessageSequence, that does not support AbstractMessageSequence.remove()
AbstractMessageSequence() - Constructor for class org.mule.routing.AbstractMessageSequence
 
AbstractMessageSequenceSplitter - Class in org.mule.routing.outbound
Base implementation of a MuleMessage splitter, that converts its payload in a MessageSequence, and process each element of it.
AbstractMessageSequenceSplitter() - Constructor for class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
AbstractMessageSplitter - Class in org.mule.routing.outbound
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.
AbstractMessageSplitter() - Constructor for class org.mule.routing.outbound.AbstractMessageSplitter
 
AbstractMessageTransformer - Class in org.mule.transformer
AbstractMessageTransformer is a transformer that has a reference to the current message.
AbstractMessageTransformer() - Constructor for class org.mule.transformer.AbstractMessageTransformer
 
AbstractMessagingExceptionStrategy - Class in org.mule.exception
Fire a notification, log exception, increment statistics, route the problematic message to a destination if one is configured (DLQ pattern), commit or rollback transaction if one exists, close any open streams.
AbstractMessagingExceptionStrategy() - Constructor for class org.mule.exception.AbstractMessagingExceptionStrategy
 
AbstractMessagingExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractMessagingExceptionStrategy
 
AbstractMetaEndpointBuilder - Class in org.mule.endpoint
A base class used for Meta endpoint builders such as RSS or ATOM.
AbstractMetaEndpointBuilder() - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractMetaEndpointBuilder(EndpointURIEndpointBuilder) - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractMetaEndpointBuilder(URIBuilder) - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractMetaEndpointBuilder(String, MuleContext) - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractMetaEndpointBuilder(EndpointURI) - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractMetaEndpointBuilder(ImmutableEndpoint) - Constructor for class org.mule.endpoint.AbstractMetaEndpointBuilder
 
AbstractModel - Class in org.mule.model
MuleModel is the default implementation of the Model.
AbstractModel() - Constructor for class org.mule.model.AbstractModel
 
AbstractMonitoredObjectStore<T extends Serializable> - Class in org.mule.util.store
TODO
AbstractMonitoredObjectStore() - Constructor for class org.mule.util.store.AbstractMonitoredObjectStore
 
AbstractMuleBeanDefinitionParser - Class in org.mule.config.spring.parsers
This parser extends the Spring provided AbstractBeanDefinitionParser to provide additional features for consistently customising bean representations for Mule bean definition parsers.
AbstractMuleBeanDefinitionParser() - Constructor for class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
AbstractMuleEventWork - Class in org.mule.work
Abstract implementation of Work to be used whenever Work needs to be scheduled that operates on a MuleEvent.
AbstractMuleEventWork(MuleEvent) - Constructor for class org.mule.work.AbstractMuleEventWork
 
AbstractMuleGuiceModule - Class in org.mule.module.guice
A mule specific Guice module that allows users to override the AbstractMuleGuiceModule.configureMuleContext(org.mule.api.MuleContext) method to do any Mule configuration such as register notifications.
AbstractMuleGuiceModule() - Constructor for class org.mule.module.guice.AbstractMuleGuiceModule
 
AbstractMuleMessageFactory - Class in org.mule.transport
 
AbstractMuleMessageFactory(MuleContext) - Constructor for class org.mule.transport.AbstractMuleMessageFactory
 
AbstractMuleNamespaceHandler - Class in org.mule.config.spring.handlers
This Namespace handler extends the default Spring NamespaceHandlerSupport to allow certain elements in document to be ignored by the handler.
AbstractMuleNamespaceHandler() - Constructor for class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
AbstractMuleObjectOwner<T> - Class in org.mule.processor
An object that owns Mule objects and delegates startup/shutdown events to them.
AbstractMuleObjectOwner() - Constructor for class org.mule.processor.AbstractMuleObjectOwner
 
AbstractNamedEncryptionStrategy - Class in org.mule.security
 
AbstractNamedEncryptionStrategy() - Constructor for class org.mule.security.AbstractNamedEncryptionStrategy
 
AbstractNotificationLoggerAgent - Class in org.mule.agent
AbstractNotificationLoggerAgent Receives Mule server notifications and logs them and can optionally route them to an endpoint.
AbstractNotificationLoggerAgent(String) - Constructor for class org.mule.agent.AbstractNotificationLoggerAgent
 
AbstractObjectFactory - Class in org.mule.object
Creates object instances based on the class and sets any properties.
AbstractObjectFactory() - Constructor for class org.mule.object.AbstractObjectFactory
For Spring only
AbstractObjectFactory(String) - Constructor for class org.mule.object.AbstractObjectFactory
 
AbstractObjectFactory(String, Map) - Constructor for class org.mule.object.AbstractObjectFactory
 
AbstractObjectFactory(Class<?>) - Constructor for class org.mule.object.AbstractObjectFactory
 
AbstractObjectFactory(Class<?>, Map) - Constructor for class org.mule.object.AbstractObjectFactory
 
AbstractObjectStore<T extends Serializable> - Class in org.mule.util.store
This is an abstract superclass for ObjectStore implementations that conforms to the contract defined in the interface's javadocs.
AbstractObjectStore() - Constructor for class org.mule.util.store.AbstractObjectStore
 
AbstractOutboundMessageProcessorBuilder - Class in org.mule.module.cxf.builder
 
AbstractOutboundMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
AbstractOutboundRouter - Class in org.mule.routing.outbound
AbstractOutboundRouter is a base router class that tracks statistics about message processing through the router.
AbstractOutboundRouter() - Constructor for class org.mule.routing.outbound.AbstractOutboundRouter
 
AbstractParallelDelegatingDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This allows a definition parsers to be dynamically represented by one instance selected from a set of parsers, depending on the context.
AbstractParallelDelegatingDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractParallelDelegatingDefinitionParser
 
AbstractParallelDelegatingDefinitionParser(MuleDefinitionParser[]) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractParallelDelegatingDefinitionParser
 
AbstractPartitionedObjectStore<T extends Serializable> - Class in org.mule.util.store
 
AbstractPartitionedObjectStore() - Constructor for class org.mule.util.store.AbstractPartitionedObjectStore
 
AbstractPipeline - Class in org.mule.construct
Abstract implementation of AbstractFlowConstruct that allows a list of AbstractPipeline.ProcessIfPipelineStartedMessageProcessors that will be used to process messages to be configured.
AbstractPipeline(String, MuleContext) - Constructor for class org.mule.construct.AbstractPipeline
 
AbstractPipeline.ProcessIfPipelineStartedMessageProcessor - Class in org.mule.construct
 
AbstractPipeline.ProcessIfPipelineStartedMessageProcessor() - Constructor for class org.mule.construct.AbstractPipeline.ProcessIfPipelineStartedMessageProcessor
 
AbstractPluggableDelegate - Class in org.mule.config.spring.parsers.delegate
Support for extending a MuleDefinitionParser without needing to subclass.
AbstractPluggableDelegate(MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
AbstractPojoNamespaceHandler - Class in org.mule.config.spring.handlers
Turns a POJO into a config element and a set of method tags which map to MessageProcessors.
AbstractPojoNamespaceHandler() - Constructor for class org.mule.config.spring.handlers.AbstractPojoNamespaceHandler
 
AbstractPolicyTemplate - Class in org.mule.retry.policies
Base class for RetryPolicyTemplate implementations.
AbstractPolicyTemplate() - Constructor for class org.mule.retry.policies.AbstractPolicyTemplate
 
AbstractPollingMessageReceiver - Class in org.mule.transport
AbstractPollingMessageReceiver implements a base class for polling message receivers.
AbstractPollingMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.AbstractPollingMessageReceiver
 
AbstractReceiverResourceWorker - Class in org.mule.transport
This is a Message receiver worker used by transports that do not have a way for the underlying transport to call back to the receiver when a message is available such as Jms.
AbstractReceiverResourceWorker(Object, AbstractMessageReceiver) - Constructor for class org.mule.transport.AbstractReceiverResourceWorker
 
AbstractReceiverResourceWorker(Object, AbstractMessageReceiver, OutputStream) - Constructor for class org.mule.transport.AbstractReceiverResourceWorker
 
AbstractReceiverServlet - Class in org.mule.transport.servlet
A base servlet used to receive requests from a servlet container and route them into Mule
AbstractReceiverServlet() - Constructor for class org.mule.transport.servlet.AbstractReceiverServlet
 
AbstractReceiverWorker - Class in org.mule.transport
A base Worker used by Transport MessageReceiver implementations.
AbstractReceiverWorker(List<Object>, AbstractMessageReceiver) - Constructor for class org.mule.transport.AbstractReceiverWorker
 
AbstractReceiverWorker(List<Object>, AbstractMessageReceiver, OutputStream) - Constructor for class org.mule.transport.AbstractReceiverWorker
 
AbstractRecipientList - Class in org.mule.routing.outbound
AbstractRecipientList is used to dispatch a single event to multiple recipients over the same transport.
AbstractRecipientList() - Constructor for class org.mule.routing.outbound.AbstractRecipientList
 
AbstractRedeliveryHandler - Class in org.mule.transport.jms.redelivery
 
AbstractRedeliveryHandler() - Constructor for class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
 
AbstractRedeliveryPolicy - Class in org.mule.processor
Implement a redelivery policy for Mule.
AbstractRedeliveryPolicy() - Constructor for class org.mule.processor.AbstractRedeliveryPolicy
 
AbstractRegistry - Class in org.mule.registry
 
AbstractRegistry(String, MuleContext) - Constructor for class org.mule.registry.AbstractRegistry
 
AbstractRegistryBroker - Class in org.mule.registry
 
AbstractRegistryBroker(MuleContext) - Constructor for class org.mule.registry.AbstractRegistryBroker
 
AbstractRemoveVariablePropertyTransformer - Class in org.mule.transformer.simple
 
AbstractRemoveVariablePropertyTransformer() - Constructor for class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
AbstractReplyToPropertyRequestReplyReplier - Class in org.mule.routing.requestreply
 
AbstractReplyToPropertyRequestReplyReplier() - Constructor for class org.mule.routing.requestreply.AbstractReplyToPropertyRequestReplyReplier
 
AbstractResourceConfigurationBuilder - Class in org.mule.config.builders
Abstract ConfigurationBuilder implementation used for ConfigurationBuider's that use one of more configuration resources of the same type that are defined using strings or ConfigResource objects.
AbstractResourceConfigurationBuilder(String) - Constructor for class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
AbstractResourceConfigurationBuilder(String[]) - Constructor for class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
AbstractResourceConfigurationBuilder(ConfigResource[]) - Constructor for class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
AbstractResourceManager - Class in org.mule.util.xa
This code is based on code coming from the commons-transaction project.
AbstractResourceManager() - Constructor for class org.mule.util.xa.AbstractResourceManager
 
AbstractResponseMessageProcessor - Class in org.mule.processor
 
AbstractResponseMessageProcessor() - Constructor for class org.mule.processor.AbstractResponseMessageProcessor
 
AbstractRetrieveMailConnector - Class in org.mule.transport.email
Support for connecting to and receiving email from a mailbox (the exact protocol depends on the subclass).
AbstractRetrieveMailConnector(int, MuleContext) - Constructor for class org.mule.transport.email.AbstractRetrieveMailConnector
 
AbstractRoundRobinMessageSplitter - Class in org.mule.routing.outbound
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.
AbstractRoundRobinMessageSplitter() - Constructor for class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
 
AbstractScriptConfigBuilderTestCase - Class in org.mule.tck
 
AbstractScriptConfigBuilderTestCase() - Constructor for class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
AbstractScriptConfigBuilderTestCase(boolean) - Constructor for class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
AbstractScriptExpressionEvaluator - Class in org.mule.module.scripting.expression
An abstract ExpressionEvaluator that can be used for any JSR-233 script engine.
AbstractScriptExpressionEvaluator() - Constructor for class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
AbstractSecurityFilter - Class in org.mule.security
AbstractSecurityFilter provides basic initialisation for all security filters, namely configuring the SecurityManager for this instance
AbstractSecurityFilter() - Constructor for class org.mule.security.AbstractSecurityFilter
 
AbstractSecurityProvider - Class in org.mule.security
 
AbstractSecurityProvider(String) - Constructor for class org.mule.security.AbstractSecurityProvider
 
AbstractSelectiveRouter - Class in org.mule.routing
 
AbstractSelectiveRouter() - Constructor for class org.mule.routing.AbstractSelectiveRouter
 
AbstractSelectiveRouterFactoryBean - Class in org.mule.config.spring.factories
 
AbstractSelectiveRouterFactoryBean() - Constructor for class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
AbstractSequenceRouter - Class in org.mule.routing.outbound
Defines a router that sequentially routes a given message to the list of registered endpoints and returns the aggregate responses as the result.
AbstractSequenceRouter() - Constructor for class org.mule.routing.outbound.AbstractSequenceRouter
 
AbstractSerialDelegatingDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This allows a set of definition parsers to be used, one after another, to process the same element.
AbstractSerialDelegatingDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
AbstractSerialDelegatingDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
AbstractService - Class in org.mule.service
A base implementation for all Services in Mule
AbstractService(MuleContext) - Constructor for class org.mule.service.AbstractService
 
AbstractServiceAndFlowTestCase - Class in org.mule.tck
 
AbstractServiceAndFlowTestCase(AbstractServiceAndFlowTestCase.ConfigVariant, String) - Constructor for class org.mule.tck.AbstractServiceAndFlowTestCase
 
AbstractServiceAndFlowTestCase.ConfigVariant - Enum in org.mule.tck
 
AbstractServiceDescriptor - Class in org.mule.api.registry
 
AbstractServiceDescriptor(String) - Constructor for class org.mule.api.registry.AbstractServiceDescriptor
 
AbstractServiceDescriptor.Key - Class in org.mule.api.registry
Unique key used to cache the service descriptors.
AbstractServiceDescriptor.Key(String, Map<?, ?>) - Constructor for class org.mule.api.registry.AbstractServiceDescriptor.Key
 
AbstractSingleParentFamilyChildDefinitionParser - Class in org.mule.config.spring.parsers.delegate
 
AbstractSingleParentFamilyChildDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyChildDefinitionParser
 
AbstractSingleParentFamilyDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This allows several parsers to be used on a single element, creating a parent bean with the first parser and then extending that with child parsers.
AbstractSingleParentFamilyDefinitionParser() - Constructor for class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
AbstractSingleParentFamilyDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
AbstractSingleResourceTransaction - Class in org.mule.transaction
This abstract class can be used as a base class for transactions that can enlist only one resource (such as a JMS session or JDBC connection).
AbstractSingleResourceTransaction(MuleContext) - Constructor for class org.mule.transaction.AbstractSingleResourceTransaction
 
AbstractSplitter - Class in org.mule.routing
Splits a message invoking the next message processor one for each split part.
AbstractSplitter() - Constructor for class org.mule.routing.AbstractSplitter
 
AbstractSynchronizedVariable - Class in org.mule.util.concurrent
 
AbstractSynchronizedVariable() - Constructor for class org.mule.util.concurrent.AbstractSynchronizedVariable
 
AbstractSynchronizedVariable(Object) - Constructor for class org.mule.util.concurrent.AbstractSynchronizedVariable
 
AbstractSystemExceptionStrategy - Class in org.mule.exception
Fire a notification, log exception, clean up transaction if any, and trigger reconnection strategy if this is a ConnectException.
AbstractSystemExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractSystemExceptionStrategy
 
AbstractTablePrinter - Class in org.mule.management.stats.printers
HtmlTablePrinter prints event processing stats as a HTML table
AbstractTablePrinter(Writer) - Constructor for class org.mule.management.stats.printers.AbstractTablePrinter
 
AbstractTablePrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.AbstractTablePrinter
 
AbstractTcpSocketFactory - Class in org.mule.transport.tcp
Creates a client socket using the socket address extracted from the endpoint.
AbstractTcpSocketFactory() - Constructor for class org.mule.transport.tcp.AbstractTcpSocketFactory
 
AbstractTlsRetrieveMailConnector - Class in org.mule.transport.email
Support for connecting to and receiving email from a secure mailbox (the exact protocol depends on the subclass).
AbstractTlsRetrieveMailConnector(int, String, Class, MuleContext) - Constructor for class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
AbstractToFromXmlTransformer - Class in org.mule.module.json.transformers
Superclass for transformers that convert JSON to and from XML
AbstractToFromXmlTransformer() - Constructor for class org.mule.module.json.transformers.AbstractToFromXmlTransformer
 
AbstractTransaction - Class in org.mule.transaction
This base class provides low level features for transactions.
AbstractTransaction(MuleContext) - Constructor for class org.mule.transaction.AbstractTransaction
 
AbstractTransactionContext - Class in org.mule.util.xa
 
AbstractTransactionContext() - Constructor for class org.mule.util.xa.AbstractTransactionContext
 
AbstractTransformer - Class in org.mule.transformer
AbstractTransformer is a base class for all transformers.
AbstractTransformer() - Constructor for class org.mule.transformer.AbstractTransformer
default constructor required for discovery
AbstractTransformPolicy - Class in org.mule.module.pgp
An abstract implementation of TransformPolicy.
AbstractTransformPolicy() - Constructor for class org.mule.module.pgp.AbstractTransformPolicy
 
AbstractTransformPolicy.TransformerWork - Class in org.mule.module.pgp
 
AbstractTransformPolicy.TransformerWork() - Constructor for class org.mule.module.pgp.AbstractTransformPolicy.TransformerWork
 
AbstractTransportMessageHandler<O> - Class in org.mule.transport
Provide a default dispatch (client) support for handling threads lifecycle and validation.
AbstractTransportMessageHandler(ImmutableEndpoint) - Constructor for class org.mule.transport.AbstractTransportMessageHandler
 
AbstractWebServiceWrapperComponent - Class in org.mule.module.cxf.component
 
AbstractWebServiceWrapperComponent() - Constructor for class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
AbstractXAResourceManager - Class in org.mule.util.xa
 
AbstractXAResourceManager() - Constructor for class org.mule.util.xa.AbstractXAResourceManager
 
AbstractXmlTransformer - Class in org.mule.module.xml.transformer
AbstractXmlTransformer offers some XSLT transform on a DOM (or other XML-ish) object.
AbstractXmlTransformer() - Constructor for class org.mule.module.xml.transformer.AbstractXmlTransformer
 
AbstractXmlTransformer.ResultHolder - Interface in org.mule.module.xml.transformer
Result callback interface used when processing XML through JAXP
AbstractXmppConversation - Class in org.mule.transport.xmpp
 
AbstractXmppConversation(ImmutableEndpoint) - Constructor for class org.mule.transport.xmpp.AbstractXmppConversation
 
AbstractXmppFilter - Class in org.mule.transport.xmpp.filters
AbstractXmppFilter is a filter adapter so that Smack Filters can be configured as Mule filters.
AbstractXmppFilter() - Constructor for class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
AbstractXPathExpressionEvaluator - Class in org.mule.module.xml.expression
Provides a base class for XPath property extractors.
AbstractXPathExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
 
AbstractXStreamTransformer - Class in org.mule.module.xml.transformer
AbstractXStreamTransformer is a base class for all XStream based transformers.
AbstractXStreamTransformer() - Constructor for class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
accept(MuleEvent) - Method in interface org.mule.api.Acceptor
 
accept(MuleMessage) - Method in interface org.mule.api.routing.filter.Filter
Check a given message against this filter.
accept(Object) - Method in interface org.mule.api.routing.filter.ObjectFilter
 
accept(MuleEvent) - Method in class org.mule.construct.AbstractPipeline.ProcessIfPipelineStartedMessageProcessor
 
accept(MuleMessage) - Method in class org.mule.example.geomail.routing.InCacheFilter
 
accept(MuleEvent) - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
accept(MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
accept(MuleEvent) - Method in class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
accept(MuleEvent) - Method in class org.mule.lifecycle.processor.ProcessIfStartedWaitIfPausedMessageProcessor
 
accept(MuleMessage) - Method in class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
accept(MuleMessage) - Method in class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
accept(MuleMessage) - Method in class org.mule.module.atom.routing.URIRouteFilter
 
accept(MuleResponseMessage) - Method in class org.mule.module.ibeans.spi.ErrorExpressionFilter
 
accept(MuleMessage) - Method in class org.mule.module.json.filters.IsJsonFilter
 
accept(Object) - Method in class org.mule.module.json.filters.IsJsonFilter
 
accept(MuleMessage) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
 
accept(MuleMessage) - Method in class org.mule.module.ognl.filters.OGNLFilter
 
accept(MuleMessage) - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
accept(MuleMessage) - Method in class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
accept(MuleEvent) - Method in class org.mule.module.scripting.filter.ScriptFilter
 
accept(MuleMessage) - Method in class org.mule.module.scripting.filter.ScriptFilter
 
accept(MuleMessage) - Method in class org.mule.module.sxc.SxcFilter
 
accept(MuleMessage) - Method in class org.mule.module.xml.filters.IsXmlFilter
 
accept(MuleMessage) - Method in class org.mule.module.xml.filters.JaxenFilter
 
accept(MuleMessage) - Method in class org.mule.module.xml.filters.JXPathFilter
 
accept(MuleMessage) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
Accepts the message if schema validation passes.
accept(MuleMessage) - Method in class org.mule.module.xml.filters.XPathFilter
 
accept(Node) - Method in class org.mule.module.xml.filters.XPathFilter
 
accept(MuleEvent) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
accept(MuleMessage) - Method in class org.mule.routing.filters.AcceptAllFilter
 
accept(Object) - Method in class org.mule.routing.filters.AcceptAllFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.ConsumableMuleMessageFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.EqualsFilter
 
accept(Object) - Method in class org.mule.routing.filters.EqualsFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.ExceptionTypeFilter
Check a given message against this filter.
accept(MuleMessage) - Method in class org.mule.routing.filters.ExpressionFilter
Check a given message against this filter.
accept(MuleMessage) - Method in class org.mule.routing.filters.logic.AndFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.logic.NotFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.logic.OrFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.PayloadTypeFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.RegExFilter
 
accept(Object) - Method in class org.mule.routing.filters.RegExFilter
 
accept(MuleMessage) - Method in class org.mule.routing.filters.WildcardFilter
 
accept(Object) - Method in class org.mule.routing.filters.WildcardFilter
 
accept(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
accept(MuleEvent) - Method in class org.mule.routing.MessageFilter
 
accept(MuleEvent) - Method in class org.mule.transaction.constraints.BatchConstraint
 
accept(MuleEvent) - Method in class org.mule.transaction.constraints.ConstraintFilter
 
accept(MuleEvent) - Method in class org.mule.transaction.constraints.ManualConstraint
 
accept(MuleMessage) - Method in class org.mule.transport.email.filters.AbstractMailFilter
 
accept(Message) - Method in class org.mule.transport.email.filters.AbstractMailFilter
 
accept(Message) - Method in class org.mule.transport.email.filters.MailSubjectRegExFilter
 
accept(Object) - Method in class org.mule.transport.file.filters.FilenameRegexFilter
Filter condition decider method.
accept(File, String) - Method in class org.mule.transport.file.filters.FilenameWildcardFilter
Filter condition decider method.
accept(MuleMessage) - Method in class org.mule.transport.file.filters.FilenameWildcardFilter
 
accept(MuleMessage) - Method in class org.mule.transport.http.filters.HttpRequestWildcardFilter
 
accept(MuleMessage) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
 
accept(MuleMessage) - Method in class org.mule.transport.jms.filters.JmsSelectorFilter
 
accept(Packet) - Method in class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
accept(MuleMessage) - Method in class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
accept(AnnotationInfo) - Method in interface org.mule.util.scan.annotations.AnnotationFilter
Should the annotation represented by an AnnotationInfo object be accepted
accept(AnnotationInfo) - Method in class org.mule.util.scan.annotations.AnnotationTypeFilter
 
accept(AnnotationInfo) - Method in class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
 
AcceptAllFilter - Class in org.mule.routing.filters
A filter that accepts everything.
AcceptAllFilter() - Constructor for class org.mule.routing.filters.AcceptAllFilter
 
acceptMessageForFlowConstruct(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
Acceptor - Interface in org.mule.api
Provides capability to only accept handling certain MuleEvents.
acceptsAll() - Method in interface org.mule.api.Acceptor
 
acceptsAll() - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
acceptsAll() - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
AccessibleLog4jLoggerAdapter - Class in org.mule.module.logging
A copy & paste of the AccessibleLog4jLoggerAdapter, just making it non-final.
AccumulatorComponent - Class in org.mule.example.scripting
Component which accumulates successive numbers, by adding/subtracting/multiplying/dividing.
AccumulatorComponent() - Constructor for class org.mule.example.scripting.AccumulatorComponent
 
ackExpression - Variable in class org.mule.construct.builder.ValidatorBuilder
 
ackExpression(String) - Method in class org.mule.construct.builder.ValidatorBuilder
 
ackParams - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
ackStmt - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
action - Variable in class org.mule.api.context.notification.ServerNotification
 
action - Variable in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
ACTION - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
ACTION_ABORT - Static variable in class org.mule.module.bpm.Process
 
ACTION_ADVANCE - Static variable in class org.mule.module.bpm.Process
 
ACTION_ALWAYS_BEGIN - Static variable in interface org.mule.api.transaction.TransactionConfig
Will ensure that a new transaction is created for each invocation
ACTION_ALWAYS_BEGIN_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_ALWAYS_JOIN - Static variable in interface org.mule.api.transaction.TransactionConfig
There must always be a transaction present for the invocation
ACTION_ALWAYS_JOIN_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_BEGIN_OR_JOIN - Static variable in interface org.mule.api.transaction.TransactionConfig
Will begin a new transaction if no transaction is already present
ACTION_BEGIN_OR_JOIN_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_DEFAULT - Static variable in interface org.mule.api.transaction.TransactionConfig
Transaction action by default.
ACTION_DISPATCH - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
 
ACTION_INDIFFERENT - Static variable in interface org.mule.api.transaction.TransactionConfig
Be indifferent to any active transaction.
ACTION_INDIFFERENT_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_INVOKE - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
 
ACTION_JOIN_IF_POSSIBLE - Static variable in interface org.mule.api.transaction.TransactionConfig
If there is a transaction available, then use it, otherwise continue processing
ACTION_JOIN_IF_POSSIBLE_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_NEVER - Static variable in interface org.mule.api.transaction.TransactionConfig
There must not be a transaction present for the invocation
ACTION_NEVER_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_NONE - Static variable in interface org.mule.api.transaction.TransactionConfig
Whether there is a transaction available or not, ignore it
ACTION_NONE_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_NOT_SUPPORTED - Static variable in interface org.mule.api.transaction.TransactionConfig
 
ACTION_NOT_SUPPORTED_STRING - Static variable in class org.mule.transaction.MuleTransactionConfig
 
ACTION_RECEIVE - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
 
ACTION_SEND - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
 
ACTION_START - Static variable in class org.mule.module.bpm.Process
 
ACTION_UPDATE - Static variable in class org.mule.module.bpm.Process
 
ACTION_WIRE_FORMAT - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
 
activate() - Method in interface org.mule.api.transport.MessageDispatcher
This method can perform necessary state updates before any of the MessageDispatching methods are invoked.
activate(OutboundEndpoint, MessageDispatcher) - Method in interface org.mule.api.transport.MessageDispatcherFactory
Invoked before the given dispatcher is handed out to a client, but not after MessageDispatcherFactory.create(OutboundEndpoint).
activate() - Method in interface org.mule.api.transport.MessageRequester
This method can perform necessary state updates before any of the MessageDispatching methods are invoked.
activate(InboundEndpoint, MessageRequester) - Method in interface org.mule.api.transport.MessageRequesterFactory
Invoked before the given requester is handed out to a client, but not after MessageRequesterFactory.create(org.mule.api.endpoint.InboundEndpoint).
activate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
activate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
activate() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
activate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
activate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
activateObject(Object) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
activateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
activateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
activateObject(Object) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
activateObject(Object, Object) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
activateObject(Object, Object) - Method in class org.mule.transport.udp.UdpSocketFactory
 
activeContexts - Variable in class org.mule.util.xa.AbstractXAResourceManager
 
ACTIVEMQ_CONNECTION_FACTORY_CLASS - Static variable in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
ACTIVEMQ_XA_CONNECTION_FACTORY_CLASS - Static variable in class org.mule.transport.jms.activemq.ActiveMQXAJmsConnector
 
ActiveMQJmsConnector - Class in org.mule.transport.jms.activemq
ActiveMQ 4.x-specific JMS connector.
ActiveMQJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.activemq.ActiveMQJmsConnector
Constructs a new ActiveMQJmsConnector.
ActiveMQXAJmsConnector - Class in org.mule.transport.jms.activemq
 
ActiveMQXAJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.activemq.ActiveMQXAJmsConnector
 
add(FlowConstructStatistics) - Method in class org.mule.management.stats.AllStatistics
 
add(int, E) - Method in class org.mule.module.launcher.util.ObservableList
 
add(E) - Method in class org.mule.module.launcher.util.ObservableList
 
add(E) - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
add(Object, Object) - Static method in class org.mule.transport.http.multipart.LazyList
Add an item to a LazyList
add(Object, int, Object) - Static method in class org.mule.transport.http.multipart.LazyList
Add an item to a LazyList
add(K, Object) - Method in class org.mule.transport.http.multipart.MultiMap
Add value to multi valued entry.
add(Object) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
addAggregate(AggregateCounter) - Method in class org.mule.util.counters.impl.AbstractCounter
 
addAlias(String, String) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addAlias(String, String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addAlias(String, String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addAlias(String, String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addAlias(String, String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
addAlias(String, String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addAlias(String, Class<?>) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
addAll(Collection<? extends E>) - Method in class org.mule.module.launcher.util.ObservableList
 
addAll(int, Collection<? extends E>) - Method in class org.mule.module.launcher.util.ObservableList
 
addAll(Collection<? extends Serializable>) - Method in class org.mule.util.queue.DefaultQueueInfoDelegate
 
addAll(Collection<? extends Serializable>) - Method in interface org.mule.util.queue.QueueInfoDelegate
Appends all of the elements in the specified collection to the queue (optional operation).
addAllListenerSubscriptionPairs(Collection<?>) - Method in class org.mule.context.notification.ServerNotificationManager
 
addAnnotatedEntryPointResolver() - Method in class org.mule.model.resolvers.LegacyEntryPointResolverSet
 
addAnnotationsConfigBuilder(List<ConfigurationBuilder>) - Method in class org.mule.MuleServer
If the annotations module is on the classpath, add the annotations config builder to the list.
addAnnotationsConfigBuilderIfPresent(List<ConfigurationBuilder>) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
addAnnotationValue(MutablePropertyValues, QName, Object) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Add a key/value pair to existing AnnotatedObject.PROPERTY_NAME property value.
addApplicationConfigEntry(String, AppConfigurationEntry) - Static method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
Adds the Configuration Entries
addApplicationListener(ApplicationListener) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Adds a listener to the the Multicaster.
addApplicationListenerBean(String) - Method in class org.mule.module.spring.events.MuleEventMulticaster
 
addArgument(ExpressionArgument) - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
 
addArray(Object, Object[]) - Static method in class org.mule.transport.http.multipart.LazyList
Add the contents of an array to a LazyList
addAttachment(String, DataHandler) - Method in interface org.mule.api.MuleMessage
Deprecated. use MuleMessage.addOutboundAttachment(java.lang.String, javax.activation.DataHandler) instead
addAttachment(String, DataHandler) - Method in class org.mule.DefaultMuleMessage
Deprecated. 
addAttachment(String, DataHandler) - Method in class org.mule.module.ibeans.spi.MuleRequestMessage
 
addAttachmentHeaders(String, Part, MuleMessage) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addAttachments(DefaultMuleMessage, Object) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
addAttachments(DefaultMuleMessage, Object) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addAttachments(DefaultMuleMessage, Object) - Method in class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
addAttachments(MuleEvent, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
addAttachments(DefaultMuleMessage, Object) - Method in class org.mule.transport.soap.axis.AxisMuleMessageFactory
 
AddAttachmentTransformer - Class in org.mule.transformer.simple
 
AddAttachmentTransformer() - Constructor for class org.mule.transformer.simple.AddAttachmentTransformer
 
AddAttribute - Class in org.mule.config.spring.parsers.processors
 
AddAttribute(String, String) - Constructor for class org.mule.config.spring.parsers.processors.AddAttribute
 
addBeanFlag(String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addBeanFlag(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addBeanFlag(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addBeanFlag(String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addBeanFlag(String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addBody(String) - Method in class org.mule.util.SplashScreen
 
addBodyPartHeaders(BodyPart, String, MuleMessage) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
 
addBook(Book) - Method in interface org.mule.example.bookstore.CatalogAdminService
Add a new book to the catalog
addBook(Book) - Method in class org.mule.example.bookstore.CatalogServiceImpl
 
AddBookResponse - Class in org.mule.example.bookstore.transformers
A call to addBook() returns a Long representing the number of books in the catalog.
AddBookResponse() - Constructor for class org.mule.example.bookstore.transformers.AddBookResponse
 
addBooks(Collection<Book>) - Method in interface org.mule.example.bookstore.CatalogAdminService
Add a group of new books to the catalog
addBooks(Collection<Book>) - Method in class org.mule.example.bookstore.CatalogServiceImpl
 
addChildDelegate(MuleChildDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
addChildDelegate(String, MuleChildDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.SingleParentFamilyDefinitionParser
 
addChildDelegate(String[], MuleChildDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.SingleParentFamilyDefinitionParser
 
addClasses(ZipFileSet) - Method in class org.mule.tools.anttasks.MulePackage
add files under classes
addClassToSet(Class<T>, Set<Class<T>>, int) - Method in class org.mule.util.scan.ClasspathScanner
 
addCollection(String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addCollection(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
This will automatically generate a list and accumulate values.
addCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addCollection(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addCollection(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addCollection(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addCollection(String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addCollection(String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addCollection(Object, Collection<?>) - Static method in class org.mule.transport.http.multipart.LazyList
Add the contents of a Collection to a LazyList
addColumn(String, int) - Method in class org.mule.module.launcher.SimpleLoggingTable
Adds a new column to the table.
addCompleteExecutionTime(long) - Method in class org.mule.management.stats.ComponentStatistics
Add the complete execution time for a flow that also reports branhc execution times
addCompleteFlowExecutionTime(long) - Method in class org.mule.management.stats.FlowConstructStatistics
 
addConfig(ZipFileSet) - Method in class org.mule.tools.anttasks.MulePackage
add config files at top level
addConnection(MuleConnection) - Method in class org.mule.module.jca.MuleManagedConnection
Associate connection handle with the physical connection.
addConnectionEventListener(ConnectionEventListener) - Method in class org.mule.module.jca.MuleManagedConnection
Adds a connection event listener to the ManagedConnection instance.
addConverter(Class<? extends Converter>) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
addConverter(Converter) - Method in class org.mule.transformer.graph.TransformationGraph
 
addCookie(Cookie) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
addCookiesToClient(HttpClient, Object, String, MuleEvent, URI) - Static method in class org.mule.transport.http.CookieHelper
Adds to the client all the cookies present in the cookiesObject.
addCorrelationProperties(Message, MuleMessage, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addCreate(List, Object) - Static method in class org.mule.util.CollectionUtils
Some code uses null to indicate "unset", which makes appending items complex.
addDataRow(String[]) - Method in class org.mule.module.launcher.SimpleLoggingTable
Adds a new row of data into the table.
addDateHeader(String, long) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
addDelegate(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addDelegate(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
addDelegate(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyChildDefinitionParser
 
addDelegate(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
addDelegate(String, MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AttributeSelectionDefinitionParser
 
addDelegate(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.SingleParentFamilyDefinitionParser
 
addDelegateAsChild(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
addDeliveryModeProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
addDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.DeploymentService
 
addDestinationProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addDirectTransition(String, String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
ADDED - Static variable in class org.mule.module.launcher.util.ElementEvent
 
addEncryptionStrategy(EncryptionStrategy) - Method in interface org.mule.api.security.SecurityManager
 
addEncryptionStrategy(EncryptionStrategy) - Method in class org.mule.security.MuleSecurityManager
 
addEndpoint(MessageProcessor) - Method in class org.mule.exception.AbstractExceptionListener
 
addEnrichExpressionPair(MessageEnricher.EnrichExpressionPair) - Method in class org.mule.enricher.MessageEnricher
 
addEntryPointResolver(EntryPointResolver) - Method in interface org.mule.api.model.EntryPointResolverSet
Will add a resolver to the list of resolvers to invoke on a compoent.
addEntryPointResolver(EntryPointResolver) - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
addError(String) - Method in class org.mule.example.ReservationResponse
 
addEvent(MuleEvent) - Method in class org.mule.routing.EventGroup
Add the given event to this group.
addEventGroup(EventGroup) - Method in class org.mule.routing.correlation.EventCorrelator
 
addEventHandler(SxcFilteringOutboundRouter, XPathBuilder) - Method in class org.mule.module.sxc.SxcFilter
 
addEventHandlers(XPathBuilder, Filter) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
addExceptionListener(AbstractFlowConstruct) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
addExecutionBranchTime(boolean, long, long) - Method in class org.mule.management.stats.ComponentStatistics
Add a new execution-time measurement for one branch of processing an event
addExecutionTime(long) - Method in class org.mule.management.stats.ComponentStatistics
Add a new execution-time measurement for processing an event.
addExpirable(long, TimeUnit, Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
Adds an expirable object to monitor.
addExpirationProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addExpressionArgumentFromAttributes(Element, BeanDefinitionBuilder) - Static method in class org.mule.config.spring.parsers.specific.ExpressionTransformerDefinitionParser
 
addFile(File) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
 
addFile(File) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addFile(File) - Method in class org.mule.util.monitor.FileMonitor
Add file to listen for.
addFiles(List) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
 
addFiles(List<File>) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addFlowExecutionBranchTime(long, long) - Method in class org.mule.management.stats.FlowConstructStatistics
 
addFlowExecutionBranchTime(long) - Method in class org.mule.management.stats.ProcessingTime
Add the execution time for this branch to the flow construct's statistics
AddFlowVariableTransformer - Class in org.mule.transformer.simple
 
AddFlowVariableTransformer() - Constructor for class org.mule.transformer.simple.AddFlowVariableTransformer
 
addFromProperty(DefaultMuleMessage, Message) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addGlobalFunction(String, Function) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
addHandledException(Class) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
addHandler(ExceptionHandler) - Method in class org.mule.example.errorhandler.ErrorManager
 
addHeader(String, Object) - Method in class org.mule.module.ibeans.spi.MuleRequestMessage
 
addHeader(String, String) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
addHeader(Header) - Method in class org.mule.transport.http.HttpRequest
 
addHeader(Header) - Method in class org.mule.transport.http.HttpResponse
 
addHeader(String, String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
addHeaders(SOAPEnvelope) - Method in class org.mule.module.cxf.MuleSoapHeaders
Writes the header properties to a Soap header
addHoldersToResponse(Object, Object[]) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
addIBeansConfigurationBuilderIfPackagesConfiguredForScanning(List<ConfigurationBuilder>) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addIgnored(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addIgnored(String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addIgnoredMethod(String) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
 
addIgnoredMethods(ReflectionServiceFactoryBean, String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
addImport(String, Class<?>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
addInboundAttachment(String, DataHandler) - Method in class org.mule.DefaultMuleMessage
 
addInboundProperties(Map<String, Object>) - Method in class org.mule.DefaultMuleMessage
 
addInboundProperties(Map<String, Object>) - Method in class org.mule.MessagePropertiesContext
 
addInfo(String, Object) - Method in exception org.mule.api.MuleException
 
addInterceptors(LinkedList<CallInterceptor>) - Method in class org.mule.module.ibeans.spi.MuleIBeansPlugin
 
addInterfaceToType(Class<? extends ServerNotificationListener>, Class<? extends ServerNotification>) - Method in class org.mule.context.notification.ServerNotificationManager
 
addIntHeader(String, int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
addJMSReplyTo(MuleMessage, Message) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addLib(ZipFileSet) - Method in class org.mule.tools.anttasks.MulePackage
add files under lib
addLibrariesToClasspath(List) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
addLibrariesToClasspath(List) - Static method in class org.mule.util.ClassUtils
 
addLibraryDirectory(File, String) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addLifecycleCallback(FunctionalTestComponent.LifecycleCallback) - Static method in class org.mule.tck.functional.FunctionalTestComponent
 
addListener(ServerNotificationListener<?>) - Method in class org.mule.context.notification.ServerNotificationManager
 
addListener(FileListener) - Method in class org.mule.util.monitor.FileMonitor
Add listener to this file monitor.
addListener(TimeEventListener) - Method in class org.mule.util.timer.EventTimerTask
 
addListenerSubscription(ServerNotificationListener<?>, String) - Method in class org.mule.context.notification.ServerNotificationManager
 
addListenerSubscriptionPair(ListenerSubscriptionPair) - Method in class org.mule.context.notification.ServerNotificationManager
 
addLocalJarFilesToClasspath(File, File) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
addMailHeadersToMessageProperties(Message, DefaultMuleMessage) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addMapping(String, Map) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addMapping(String, String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addMapping(String, ValueMap) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addMapping(String, Map) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addMapping(String, String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addMapping(String, ValueMap) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addMapping(String, Map) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addMapping(String, String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addMapping(String, ValueMap) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addMessage(MuleMessage) - Method in interface org.mule.api.MuleMessageCollection
 
addMessage(MuleMessage, int) - Method in interface org.mule.api.MuleMessageCollection
 
addMessage(MuleMessage) - Method in class org.mule.DefaultMessageCollection
 
addMessage(MuleMessage, int) - Method in class org.mule.DefaultMessageCollection
 
addMessageIdProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addMessageProcessor(MessageProcessor) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
addMessageProcessor(MessageProcessor) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
addMessageProcessor(MessageProcessor) - Method in class org.mule.service.ServiceCompositeMessageSource
 
addMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.model.seda.SedaService
 
addMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.module.jca.JcaService
 
addMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.service.AbstractService
 
addMessages(MuleMessage[]) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(MuleEvent[]) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(List) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(MuleEvent[]) - Method in class org.mule.DefaultMessageCollection
 
addMessages(List) - Method in class org.mule.DefaultMessageCollection
 
addMessages(MuleMessage[]) - Method in class org.mule.DefaultMessageCollection
 
addMethod(String) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
addMethod(String) - Method in class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
addMethodByArguments(Object, Method, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
addMethodByName(Object, Method, MuleEventContext) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
addMuleBaseUserLibs(File, File) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addMuleInterceptors() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
addNamedParameter(NamedParameter) - Method in class org.mule.transport.soap.axis.SoapMethod
 
addNamedParameter(QName, QName, String) - Method in class org.mule.transport.soap.axis.SoapMethod
 
addNamedParameter(QName, QName, ParameterMode) - Method in class org.mule.transport.soap.axis.SoapMethod
 
addNamespace(String, String) - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
addNamespaces(NamespaceManager, XPath) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
 
addNamespaces(Map<String, String>) - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
addNamespacesToContext(NamespaceManager, JXPathContext) - Method in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.  
addObject(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
addObjectInitialisationCallback(InitialisationCallback) - Method in interface org.mule.api.object.ObjectFactory
Register a custom initialiser
addObjectInitialisationCallback(InitialisationCallback) - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
addObjectInitialisationCallback(InitialisationCallback) - Method in class org.mule.object.AbstractObjectFactory
 
addObjectInitialisationCallback(InitialisationCallback) - Method in class org.mule.object.JndiObjectFactory
 
addOrderedLifecycleObject(LifecycleObject) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
addOrderedLifecycleObject(LifecycleObject) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
addOutboundAttachment(String, DataHandler) - Method in interface org.mule.api.MuleMessage
Allows for arbitrary data attachments to be associated with the Message.
addOutboundAttachment(String, Object, String) - Method in interface org.mule.api.MuleMessage
Adds an outgoing attachment to the message
addOutboundAttachment(String, DataHandler) - Method in class org.mule.DefaultMuleMessage
 
addOutboundAttachment(String, Object, String) - Method in class org.mule.DefaultMuleMessage
 
addOverride(Map<String, String>, Element, String, String) - Method in class org.mule.config.spring.parsers.specific.ServiceOverridesDefinitionParser
 
addParamToContext(String, Object, VelocityContext) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
addPart(Object, OutboundEndpoint) - Method in class org.mule.routing.outbound.SplitMessage
 
addPerson(Person) - Method in interface org.mule.tck.testmodels.services.PeopleService
 
addPerson(String, String) - Method in interface org.mule.tck.testmodels.services.PeopleService
 
addPerson(Person) - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
addPerson(String, String) - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
addPostProcess(MuleDefinitionParser) - Static method in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
addPriorityProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addProcessed(Object) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
addProcessedGroup(Object) - Method in class org.mule.routing.correlation.EventCorrelator
 
addProperties(Map<String, Object>) - Method in interface org.mule.api.MuleMessage
Deprecated. use MuleMessage.addProperties(java.util.Map, org.mule.api.transport.PropertyScope) instead
addProperties(Map<String, Object>, PropertyScope) - Method in interface org.mule.api.MuleMessage
Adds a map of properties to be associated with this message
addProperties(MuleDefinitionParser) - Static method in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
addProperties(Map<String, Object>) - Method in class org.mule.DefaultMuleMessage
Adds a map of properties to be associated with this message
addProperties(Map<String, Object>, PropertyScope) - Method in class org.mule.DefaultMuleMessage
Adds a map of properties to be associated with this message
addProperties(Map<String, Object>) - Method in class org.mule.message.ExceptionMessage
Adds a map of properties to associated with this message
addProperties(MuleMessage) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.ajax.AjaxMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.soap.axis.AxisMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.udp.UdpMuleMessageFactory
 
addProperties(DefaultMuleMessage, Object) - Method in class org.mule.transport.xmpp.XmppMuleMessageFactory
 
addPropertyChangeListener(PropertyChangeListener) - Method in class org.mule.module.jca.MuleManagedConnectionFactory
Associate PropertyChangeListener with the ManagedConnectionFactory, in order to notify about properties changes.
addPropertyChangeListener(PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
addPropertyChangeListener(String, PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
AddPropertyTransformer - Class in org.mule.transformer.simple
 
AddPropertyTransformer() - Constructor for class org.mule.transformer.simple.AddPropertyTransformer
 
addPropertyWithoutReference(MutablePropertyValues, SingleProperty, String, Object) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
addPropertyWithReference(MutablePropertyValues, SingleProperty, String, Object) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
addProvider(SecurityProvider) - Method in interface org.mule.api.security.SecurityManager
 
addProvider(SecurityProvider) - Method in class org.mule.security.MuleSecurityManager
 
addProxyInterceptors(ServerFactoryBean) - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
addQueryStringToParameterMap(String, Map<String, Object>, String) - Method in class org.mule.transport.http.transformers.HttpRequestBodyToParamMap
 
addQueueStore(QueueStore<Serializable>) - Method in class org.mule.config.QueueProfile
 
addReceiver(R) - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
addReceiver(JettyHttpMessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
addRecipientProperty(MuleMessage, Message, Message.RecipientType, String) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addRedeliveredProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addReference(String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
addReference(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
addReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
addReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
addReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
addReference(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
addReference(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
addReference(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
addReference(String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
addReference(String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
addRegistry(Registry) - Method in interface org.mule.api.MuleContext
 
addRegistry(Registry) - Method in interface org.mule.api.registry.RegistryBroker
 
addRegistry(Registry) - Method in class org.mule.DefaultMuleContext
 
addRegistry(Registry) - Method in class org.mule.registry.DefaultRegistryBroker
 
addReplyToProcessors(List<MessageProcessor>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
addReplyToProperty(DefaultMuleMessage, Message) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addResolver(String, VariableResolver) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addResponseMessageProcessor(MessageProcessor) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
addResponseMessageProcessor(MessageProcessor) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
addResponseTransformer(Transformer) - Method in interface org.mule.api.endpoint.EndpointBuilder
Deprecated. Use addResponseMessageProcessor()
addResponseTransformer(Transformer) - Method in class org.mule.endpoint.AbstractEndpointBuilder
Deprecated. Use addResponseMessageProcessor()
addResponseTransformerProcessors(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
address - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
ADDRESS - Static variable in class org.mule.endpoint.URIBuilder
 
address - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
address - Variable in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
Address - Class in org.mule.tck.testmodels.services
Address is a Persons address
Address() - Constructor for class org.mule.tck.testmodels.services.Address
 
Address(String, String) - Constructor for class org.mule.tck.testmodels.services.Address
 
ADDRESS - Static variable in class org.mule.transport.rmi.config.RmiNamespaceHandler
 
ADDRESS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
ADDRESS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
ADDRESS_ATTRIBUTES - Static variable in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
ADDRESS_PROPERTY - Static variable in class org.mule.transport.udp.UdpConnector
 
AddressedEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint.support
Combine a ChildAddressDefinitionParser and either a OrphanEndpointDefinitionParser or a ChildEndpointDefinitionParser in one parser.
AddressedEndpointDefinitionParser(String, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
AddressedEndpointDefinitionParser(String, boolean, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
AddressedEndpointDefinitionParser(String, boolean, MuleDefinitionParser, String[], String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
AddressedEndpointDefinitionParser(String, boolean, MuleDefinitionParser, String[], String[], String[][], String[][]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
addressFromMessage - Variable in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
addReturnMessage(MuleMessage) - Method in interface org.mule.api.retry.RetryContext
 
addReturnMessage(MuleMessage) - Method in class org.mule.retry.async.FutureRetryContext
 
addReturnMessage(MuleMessage) - Method in class org.mule.retry.DefaultRetryContext
 
addRoute(MessageProcessor) - Method in interface org.mule.api.processor.MessageRouter
Adds a new message processor to the list of routes
addRoute(MatchableMessageProcessor) - Method in interface org.mule.api.routing.MatchingRouter
 
addRoute(MessageProcessor, Filter) - Method in interface org.mule.api.routing.SelectiveRouter
 
addRoute(MatchableMessageProcessor) - Method in class org.mule.routing.AbstractMatchingRouter
 
addRoute(MessageProcessor, Filter) - Method in class org.mule.routing.AbstractSelectiveRouter
 
addRoute(MessageProcessor) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
addRoute(MatchableMessageProcessor) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
 
addRoute(MessageProcessor) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
addRoute(MessageProcessor) - Method in class org.mule.routing.outbound.OutboundPassThroughRouter
 
addRouterForInterface(InterfaceBinding) - Method in class org.mule.component.BindingInvocationHandler
 
addRouterForInterface(InterfaceBinding) - Method in class org.mule.module.ibeans.spi.MuleCallAnnotationHandler
 
addSchedulerFactoryProperty(String, String) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
addSender(Sender) - Method in class org.mule.example.geomail.dao.impl.SenderDaoImpl
 
addSender(Sender) - Method in interface org.mule.example.geomail.dao.SenderDao
 
addSentDateProperty(DefaultMuleMessage, Message) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
AddSessionVariableTransformer - Class in org.mule.transformer.simple
 
AddSessionVariableTransformer() - Constructor for class org.mule.transformer.simple.AddSessionVariableTransformer
 
addShutdownListener(MuleApplicationClassLoader.ShutdownListener) - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
addSource(MessageSource) - Method in interface org.mule.api.source.CompositeMessageSource
 
addSource(MessageSource) - Method in class org.mule.service.ServiceCompositeMessageSource
 
addSource(MessageSource) - Method in class org.mule.source.StartableCompositeMessageSource
 
addStartupListener(DeploymentService.StartupListener) - Method in class org.mule.module.launcher.DeploymentService
 
addStartupPropertiesConfigBuilder(List<ConfigurationBuilder>) - Method in class org.mule.MuleServer
 
addTemplate(Template) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method addTemplate.
addTimestampProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addToArray(Object[], Object, Class<?>) - Static method in class org.mule.transport.http.multipart.LazyList
Add element to an array
addToEnvironment(String, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
addToEnvironment(String, Object) - Method in class org.mule.jndi.SimpleContext
 
addToEnvironment(String, Object) - Method in class org.mule.tck.jndi.InMemoryContext
 
addToParameterMap(Map<String, Object>, String, String) - Method in class org.mule.transport.http.transformers.HttpRequestBodyToParamMap
 
addTransformer(Transformer) - Method in interface org.mule.api.endpoint.EndpointBuilder
Deprecated. Use addMessageProcessor()
addTransformer(Transformer) - Method in class org.mule.endpoint.AbstractEndpointBuilder
Deprecated. Use addMessageProcessor()
addTransformerProcessors(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
addTypeProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addUriParamsAsHeaders(Map, String) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
addURL(URL) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
Add a URL to Mule's classpath.
addURL(URL) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
Add a URL to Mule's classpath.
addURLs(List) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
Setter for property 'urls'.
addURLs(List<URL>) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addValues(K, List) - Method in class org.mule.transport.http.multipart.MultiMap
Add values to multi valued entry.
addValues(K, String[]) - Method in class org.mule.transport.http.multipart.MultiMap
Add values to multi valued entry.
addVariable(Variable) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method addVariable.
addVariable(Variable) - Method in class com.javaforge.bobber.archetype.model.Variable
Method addVariable.
addVariable(String, T) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
addVariable(String, T, VariableAssignmentCallback<T>) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
addVariable(String, T) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addVariable(String, T, VariableAssignmentCallback<T>) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addZombie(File) - Method in class org.mule.module.launcher.DeploymentService
 
ADMIN_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
advanceGeneration(String) - Method in class org.mule.module.management.mbean.YourKitProfilerService
Advance current object generation number.
advanceGeneration(String) - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Advance current object generation number.
advanceProcess(Object, Object, Map) - Method in interface org.mule.module.bpm.BPMS
Advance an already-running process.
advanceProcess(Object) - Method in class org.mule.module.jbpm.Jbpm
Advance a process instance one step.
advanceProcess(Object, Object, Map) - Method in class org.mule.module.jbpm.Jbpm
Advance a process instance one step.
after(MuleEvent) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
This method is invoked after the event has been processed, unless an exception was thrown
after(MuleEvent) - Method in class org.mule.interceptor.LoggingInterceptor
 
after(MuleEvent) - Method in class org.mule.interceptor.ProcessingTimeInterceptor
 
afterCall(InvocationContext) - Method in class org.mule.module.ibeans.spi.MuleResponseTransformInterceptor
 
afterExecute(Object, Method, Object[]) - Method in interface org.mule.util.Multicaster.InvokeListener
 
afterPropertiesSet() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
afterPropertiesSet() - Method in class org.mule.config.spring.util.SystemPropertyInitializingBean
Sets the system properties
afterRouting(Exception, MuleEvent) - Method in class org.mule.exception.CatchMessagingExceptionStrategy
 
afterRouting(Exception, MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
Agent - Interface in org.mule.api.agent
Agent is a server plugin that can be initialised, started and destroyed along with the MuleContext itself.
AGENT_NAME - Static variable in class org.mule.module.client.remoting.RemoteDispatcherAgent
 
agentsRunning() - Static method in class org.mule.config.i18n.CoreMessages
 
aggregate(AbstractSingleResourceTransaction) - Method in interface org.mule.transaction.TransactionCollection
 
AggregateCounter - Class in org.mule.util.counters.impl
 
AggregateCounter(String, CounterFactory.Type, AbstractCounter) - Constructor for class org.mule.util.counters.impl.AggregateCounter
 
aggregateEvents(EventGroup) - Static method in class org.mule.example.loanbroker.routers.BankQuotesAggregationLogic
 
aggregateEvents(EventGroup) - Method in class org.mule.example.loanbroker.routers.BankQuotesInboundAggregator
This method is invoked if the shouldAggregate method is called and returns true.
aggregateEvents(EventGroup) - Method in class org.mule.routing.AbstractCorrelationAggregator
 
aggregateEvents(EventGroup) - Method in class org.mule.routing.correlation.CollectionCorrelatorCallback
This method is invoked if the shouldAggregate method is called and returns true.
aggregateEvents(EventGroup) - Method in interface org.mule.routing.correlation.EventCorrelatorCallback
This method is invoked if the shouldAggregate method is called and returns true.
aggregateEvents(EventGroup) - Method in class org.mule.routing.correlation.ResequenceCorrelatorCallback
This method is invoked if the shouldAggregate method is called and returns true.
aggregateEvents(EventGroup) - Method in class org.mule.routing.correlation.ResequenceMessagesCorrelatorCallback
This method is invoked if the shouldAggregate method is called and returns true.
aggregateResults(List<MuleEvent>, MuleEvent, MuleContext) - Method in interface org.mule.api.routing.RouterResultsHandler
 
aggregateResults(List<MuleEvent>, MuleEvent, MuleContext) - Method in class org.mule.routing.DefaultRouterResultsHandler
 
AggregationException - Exception in org.mule.routing
TODO document
AggregationException(EventGroup, MessageProcessor) - Constructor for exception org.mule.routing.AggregationException
 
AggregationException(EventGroup, MessageProcessor, Throwable) - Constructor for exception org.mule.routing.AggregationException
 
AggregationException(Message, EventGroup, MessageProcessor) - Constructor for exception org.mule.routing.AggregationException
 
AggregationException(Message, EventGroup, MessageProcessor, Throwable) - Constructor for exception org.mule.routing.AggregationException
 
Aggregator - Interface in org.mule.api.routing
 
AggregatorDefinitionParser - Class in org.mule.config.spring.parsers.specific
Generic router definition parser for parsing all Router elements.
AggregatorDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.AggregatorDefinitionParser
 
AggregatorDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.AggregatorDefinitionParser
 
AJAX_PATH_SPEC - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
 
AjaxConnector - Class in org.mule.transport.ajax.embedded
Creates an 'embedded' Ajax server using Jetty and allows Mule to receiver and send events to browsers.
AjaxConnector(MuleContext) - Constructor for class org.mule.transport.ajax.embedded.AjaxConnector
 
AjaxMessageDispatcher - Class in org.mule.transport.ajax
Will dispatch Mule events to ajax clients available in Bayeux that are listening to this endpoint.
AjaxMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.ajax.AjaxMessageDispatcher
 
AjaxMessageDispatcherFactory - Class in org.mule.transport.ajax
Creates a AjaxMessageDispatcher
AjaxMessageDispatcherFactory() - Constructor for class org.mule.transport.ajax.AjaxMessageDispatcherFactory
 
AjaxMessageReceiver - Class in org.mule.transport.ajax
Registers a receiver service with Bayeux.
AjaxMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.ajax.AjaxMessageReceiver
 
AjaxMessageReceiver.ReceiverService - Class in org.mule.transport.ajax
 
AjaxMessageReceiver.ReceiverService(String, Bayeux, ImmutableEndpoint) - Constructor for class org.mule.transport.ajax.AjaxMessageReceiver.ReceiverService
 
AjaxMessages - Class in org.mule.transport.ajax.i18n
i18n messages for the Ajax transport
AjaxMessages() - Constructor for class org.mule.transport.ajax.i18n.AjaxMessages
 
AjaxMuleMessageFactory - Class in org.mule.transport.ajax
A MuleMessageFactory implementation for JSON messages.
AjaxMuleMessageFactory(MuleContext) - Constructor for class org.mule.transport.ajax.AjaxMuleMessageFactory
 
AjaxNamespaceHandler - Class in org.mule.transport.ajax.config
Registers a Bean Definition Parser for handling <ajax:connector> elements and <ajax:servlet-connector> elements.
AjaxNamespaceHandler() - Constructor for class org.mule.transport.ajax.config.AjaxNamespaceHandler
 
AjaxReplyToHandler - Class in org.mule.transport.ajax
Handles the sending of sending result messages back to the client when the a replyTo channel is specified in the client request.
AjaxReplyToHandler(Connector) - Constructor for class org.mule.transport.ajax.AjaxReplyToHandler
 
AjaxServletConnector - Class in org.mule.transport.ajax.container
A servlet connector that binds to the container and makes a configured Bayeux available to dispatchers and receivers.
AjaxServletConnector(MuleContext) - Constructor for class org.mule.transport.ajax.container.AjaxServletConnector
 
algorithm - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
aliases - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
ALL_ARGUMENT - Static variable in class org.mule.expression.ExpressionConstants
 
ALL_ATTRIBUTES - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
ALL_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
ALL_HEADER_NAMES - Static variable in class org.mule.transport.http.HttpConstants
 
ALL_PHASES - Static variable in interface org.mule.api.lifecycle.LifecyclePhase
 
ALL_SCOPES - Static variable in class org.mule.api.transport.PropertyScope
An array of all scopes defined here
ALL_TRANSPORT_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
AllAttributeChildDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This is a very hurried demonstration.
AllAttributeChildDefinitionParser(DynamicAttributeDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
allKeys() - Method in interface org.mule.api.store.ListableObjectStore
 
allKeys(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
allKeys() - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
allKeys() - Method in class org.mule.util.store.ManagedObjectStore
 
allKeys() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
allKeys() - Method in class org.mule.util.store.ObjectStorePartition
 
allKeys(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
allKeys() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
allKeys(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
allKeys() - Method in class org.mule.util.store.QueuePersistenceObjectStore
 
allKeys() - Method in class org.mule.util.store.QueueStoreAdapter
 
allKeys() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
allocateConnection(ManagedConnectionFactory, ConnectionRequestInfo) - Method in class org.mule.module.jca.DefaultConnectionManager
 
ALLOCATION_RECORDING_ADAPTIVE - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
ALLOCATION_RECORDING_ALL - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
allPartitions() - Method in interface org.mule.api.store.PartitionableObjectStore
 
allPartitions() - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
allPartitions() - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
AllStatistics - Class in org.mule.management.stats
AllStatistics TODO
AllStatistics() - Constructor for class org.mule.management.stats.AllStatistics
 
ANCHOR_FILE_BLURB - Static variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
and(String, MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
and(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
AndFilter - Class in org.mule.routing.filters.logic
AndFilter accepts only if all the filters accept.
AndFilter() - Constructor for class org.mule.routing.filters.logic.AndFilter
 
AndFilter(Filter...) - Constructor for class org.mule.routing.filters.logic.AndFilter
 
AndFilter(List<Filter>) - Constructor for class org.mule.routing.filters.logic.AndFilter
 
AnnotatedEndpointData - Class in org.mule.config.endpoint
Provides a generic endpoint data wrapper so that we can just use a single method for processing endpoints and reduce a load of duplication
AnnotatedEndpointData(MessageExchangePattern, ChannelType, Annotation) - Constructor for class org.mule.config.endpoint.AnnotatedEndpointData
 
AnnotatedEndpointHelper - Class in org.mule.config.endpoint
This is a wrapper helper that can process AnnotatedEndpointData objects (Annotaiton config data) and turn them into EndpointBuilder or ImmutableEndpoint objects.
AnnotatedEndpointHelper(MuleContext) - Constructor for class org.mule.config.endpoint.AnnotatedEndpointHelper
 
AnnotatedEntryPointResolver - Class in org.mule.impl.model.resolvers
A Mule EntryPointResolver implementation that will resolve methods on a service class that have Mule expression annotations such as Payload, InboundHeaders It will transform the received message to match the annotated method arguments.
AnnotatedEntryPointResolver() - Constructor for class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
AnnotatedObject - Interface in org.mule.api
 
AnnotatedService - Annotation Type in org.mule.module.guice
TODO
AnnotatedTransformerObjectProcessor - Class in org.mule.config.transformer
Will check all method level annotations to see if there are any Transformer annotations present.
AnnotatedTransformerObjectProcessor() - Constructor for class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
 
AnnotatedTransformerObjectProcessor(MuleContext) - Constructor for class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
 
AnnotatedTransformerProxy - Class in org.mule.config.transformer
Creates a Mule Transformer proxy around a transform method.
AnnotatedTransformerProxy(int, Object, Method, Class[], String, String) - Constructor for class org.mule.config.transformer.AnnotatedTransformerProxy
 
AnnotationException - Exception in org.mule.api
Root exception for errors related to annotation parsing
AnnotationException(Message) - Constructor for exception org.mule.api.AnnotationException
 
AnnotationException(Message, Throwable) - Constructor for exception org.mule.api.AnnotationException
 
AnnotationFilter - Interface in org.mule.util.scan.annotations
A filter is used when performing an Annotation scan on a single class or the classpath.
AnnotationInfo - Class in org.mule.util.scan.annotations
 
AnnotationInfo() - Constructor for class org.mule.util.scan.annotations.AnnotationInfo
 
AnnotationInfo.NameValue - Class in org.mule.util.scan.annotations
 
AnnotationMetaData - Class in org.mule.util.annotation
A data class that associates context information about an annotation.
AnnotationMetaData(Class, Member, ElementType, Annotation) - Constructor for class org.mule.util.annotation.AnnotationMetaData
 
ANNOTATIONS_PACKAGE_NAME - Static variable in class org.mule.module.json.transformers.JsonMapperResolver
 
AnnotationsConfigurationBuilder - Class in org.mule.config
Enables Mule annotation processing so that annotated objects registered with the Mule registry will automatically be configured.
AnnotationsConfigurationBuilder() - Constructor for class org.mule.config.AnnotationsConfigurationBuilder
 
AnnotationsMessages - Class in org.mule.config.i18n
Internationalized messages specific to the annotations module
AnnotationsMessages() - Constructor for class org.mule.config.i18n.AnnotationsMessages
 
AnnotationsParserFactory - Interface in org.mule.config
Defines a common interface to find all Endpoint annotation parsers for a context.
annotationsRequireJava5() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
AnnotationsScanner - Class in org.mule.util.scan.annotations
Scans a single class and registers all annotations on the class in four collections; class annotations, field annotations method annotations and parameter annotations.
AnnotationsScanner() - Constructor for class org.mule.util.scan.annotations.AnnotationsScanner
 
AnnotationsScanner(AnnotationFilter) - Constructor for class org.mule.util.scan.annotations.AnnotationsScanner
 
AnnotationTypeFilter - Class in org.mule.util.scan.annotations
Simply filters for annotations that match the annotation class
AnnotationTypeFilter(Class<? extends Annotation>) - Constructor for class org.mule.util.scan.annotations.AnnotationTypeFilter
 
AnnotationUtils - Class in org.mule.util.annotation
A helper class for reading annotations.
AnnotationUtils() - Constructor for class org.mule.util.annotation.AnnotationUtils
 
ANOTHER_DEPLOYMENT_OPERATION_IS_IN_PROGRESS - Static variable in class org.mule.module.launcher.DeploymentService
 
ANT_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
ANT_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
ANY - Static variable in interface org.mule.transformer.types.MimeTypes
 
ANY_MIME_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
APACHE_XML_FEATURES_VALIDATION_SCHEMA - Static variable in class org.mule.module.xml.routing.XmlMessageSplitter
 
APACHE_XML_FEATURES_VALIDATION_SCHEMA - Static variable in class org.mule.module.xml.util.XMLUtils
 
APACHE_XML_FEATURES_VALIDATION_SCHEMA_FULL_CHECKING - Static variable in class org.mule.module.xml.routing.XmlMessageSplitter
 
APACHE_XML_FEATURES_VALIDATION_SCHEMA_FULL_CHECKING - Static variable in class org.mule.module.xml.util.XMLUtils
 
APP_ANCHOR_SUFFIX - Static variable in class org.mule.module.launcher.DeploymentService
 
APP_HOME_DIRECTORY_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
APP_NAME_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
appAnchors - Variable in class org.mule.module.launcher.DeploymentService.AppDirWatcher
 
AppBloodhound - Interface in org.mule.module.launcher
Discovers application descriptor and settings.
AppContext - Class in org.mule.el.context
Exposes information about the current Mule Application: encoding Application default encoding name Application name registry Mule registry (as a map) standalone If Mule is running standalone workdir Application work directory
AppContext(MuleContext) - Constructor for class org.mule.el.context.AppContext
 
AppDeployerMonitorThreadFactory - Class in org.mule.module.launcher
 
AppDeployerMonitorThreadFactory() - Constructor for class org.mule.module.launcher.AppDeployerMonitorThreadFactory
 
appDirMonitorTimer - Variable in class org.mule.module.launcher.DeploymentService
 
append(String) - Method in class org.mule.example.hello.ChatString
 
append(StringBuffer) - Method in class org.mule.example.hello.ChatString
 
append(String, MuleMessage) - Method in class org.mule.tck.functional.FunctionalTestComponent
Will append the value of FunctionalTestComponent.getAppendString() to the contents of the message.
append(String, String) - Static method in class org.mule.transformer.simple.StringAppendTransformer
 
append2digits(StringBuffer, int) - Static method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
appendDefault(String) - Static method in class org.mule.tck.functional.StringAppendTestTransformer
 
appendFactory(VariableResolverFactory) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
appendJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
 
appendMessage(String) - Method in exception org.mule.api.MuleException
 
appFactory - Variable in class org.mule.module.launcher.DeploymentService
 
APPLICATION - Static variable in class org.mule.api.transport.PropertyScope
This provides access to properties in the registry.
Application - Interface in org.mule.module.launcher.application
 
APPLICATION_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
APPLICATION_XML - Static variable in interface org.mule.transformer.types.MimeTypes
 
ApplicationAwareRepositorySelector - Class in org.mule.module.launcher.log4j
 
ApplicationAwareRepositorySelector() - Constructor for class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector
 
ApplicationAwareRepositorySelector.ConfigWatchDog - Class in org.mule.module.launcher.log4j
 
ApplicationAwareRepositorySelector.ConfigWatchDog(ClassLoader, String, LoggerRepository) - Constructor for class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector.ConfigWatchDog
 
ApplicationAwareRepositorySelector.LoggerRepositoryCache - Class in org.mule.module.launcher.log4j
 
ApplicationAwareRepositorySelector.LoggerRepositoryCache() - Constructor for class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector.LoggerRepositoryCache
 
applicationContext - Variable in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
applicationContext - Variable in class org.mule.config.spring.SpringRegistry
 
applicationContext - Variable in class org.mule.module.spring.events.MuleEventMulticaster
The Spring application context
ApplicationDescriptor - Class in org.mule.module.launcher.descriptor
 
ApplicationDescriptor() - Constructor for class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
ApplicationEventException - Exception in org.mule.module.spring.events
ApplicationEventException TODO
ApplicationEventException(String) - Constructor for exception org.mule.module.spring.events.ApplicationEventException
 
ApplicationEventException(String, Throwable) - Constructor for exception org.mule.module.spring.events.ApplicationEventException
 
ApplicationFactory - Interface in org.mule.module.launcher.application
Creates Application instances
applicationFactory - Variable in class org.mule.module.launcher.DefaultMuleDeployer
 
ApplicationMuleContextBuilder - Class in org.mule.module.launcher
Takes Mule application descriptor into account when building the context.
ApplicationMuleContextBuilder(ApplicationDescriptor) - Constructor for class org.mule.module.launcher.ApplicationMuleContextBuilder
 
ApplicationService - Class in org.mule.module.management.mbean
The MBean for application-wide statistics
ApplicationService(String, String, MuleContext, FlowConstructStatistics) - Constructor for class org.mule.module.management.mbean.ApplicationService
 
applicationShutdownNormally(String, Date) - Static method in class org.mule.config.i18n.CoreMessages
 
ApplicationShutdownSplashScreen - Class in org.mule.util
 
ApplicationShutdownSplashScreen() - Constructor for class org.mule.util.ApplicationShutdownSplashScreen
 
ApplicationStartupSplashScreen - Class in org.mule.util
 
ApplicationStartupSplashScreen() - Constructor for class org.mule.util.ApplicationStartupSplashScreen
 
ApplicationStatistics - Class in org.mule.management.stats
Aggregate statistics for all services and flows in an application.
ApplicationStatistics(AllStatistics) - Constructor for class org.mule.management.stats.ApplicationStatistics
 
applicationWasUpForDuration(long) - Static method in class org.mule.config.i18n.CoreMessages
 
ApplicationWrapper - Class in org.mule.module.launcher.application
Decorates the target deployer to properly switch out context classloader for deployment one where applicable.
ApplicationWrapper(Application) - Constructor for class org.mule.module.launcher.application.ApplicationWrapper
 
applyAllTransformers(MuleEvent, List<? extends Transformer>) - Method in class org.mule.DefaultMuleMessage
 
applyCompletedPhases(Object) - Method in interface org.mule.api.lifecycle.RegistryLifecycleHelpers
Successively applies all completed lifecycle phase to an object.
applyCompletedPhases(Object) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
applyInboundTransformers(MuleEvent) - Method in class org.mule.transport.AbstractMessageReceiver
 
applyInboundTransformers(MuleMessage) - Method in class org.mule.transport.AbstractMessageRequester
 
applyInitialisationPolicy() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
applyLifecycle(Object) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
applyLifecycle(Object) - Method in interface org.mule.api.registry.MuleRegistry
Will execute any lifecycle phases on an object without actually registering the object in the registry.
applyLifecycle(Object, String) - Method in interface org.mule.api.registry.MuleRegistry
 
applyLifecycle(LifecycleManager) - Method in class org.mule.config.builders.AbstractConfigurationBuilder
Allows a configuration builder to check and customise the lifecycle of objects in the registry being used.
applyLifecycle(LifecycleManager) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
applyLifecycle(Object) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
applyLifecycle(Object) - Method in class org.mule.lifecycle.phases.MuleContextDisposePhase
 
applyLifecycle(Object) - Method in class org.mule.lifecycle.phases.MuleContextInitialisePhase
 
applyLifecycle(Object) - Method in class org.mule.registry.MuleRegistryHelper
Will execute any lifecycle phases on an object without actually registering the object in the registry.
applyLifecycle(Object, String) - Method in class org.mule.registry.MuleRegistryHelper
 
applyLifecycle(MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
applyLifecycle(MessageRequester, boolean) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
applyOutboundTransformers(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
 
applyOutboundTransformers(MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
applyPhase(Object, String, String) - Method in interface org.mule.api.lifecycle.RegistryLifecycleHelpers
Applies lifecycle phase to an object independent of the current lifecycle phase.
applyPhase(Object, String, String) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
applyPolicy(Throwable) - Method in interface org.mule.api.retry.RetryPolicy
 
applyPolicy(Throwable) - Method in class org.mule.retry.policies.NoRetryPolicyTemplate.NoRetryPolicy
 
applyPolicy(Throwable) - Method in class org.mule.retry.policies.SimpleRetryPolicy
 
applyProcessors(Object) - Method in interface org.mule.api.registry.MuleRegistry
Will execute any processors on an object without actually registering the object in the registry.
applyProcessors(Object, int) - Method in interface org.mule.api.registry.MuleRegistry
Will execute any processors on an object without actually registering the object in the registry.
applyProcessors(Object) - Method in class org.mule.registry.MuleRegistryHelper
Will execute any processors on an object without actually registering the object in the registry.
applyProcessors(Object, int) - Method in class org.mule.registry.MuleRegistryHelper
Will execute any processors on an object without actually registering the object in the registry.
applyProcessors(Map<String, Object>) - Method in class org.mule.registry.TransientRegistry
 
applyProcessorsAndLifecycle(Object) - Method in interface org.mule.api.registry.MuleRegistry
Will execute any processors on an object and fire any lifecycle methods according to the current lifecycle without actually registering the object in the registry.
applyProcessorsAndLifecycle(Object) - Method in class org.mule.registry.MuleRegistryHelper
Will execute any processors on an object and fire any lifecycle methods according to the current lifecycle without actually registering the object in the registry.
applyResponseTransformers(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
 
applyResponseTransformers(MuleEvent) - Method in class org.mule.transport.AbstractMessageReceiver
 
applySystemProperties() - Method in class org.mule.config.DefaultMuleConfiguration
Apply any settings which come from the JVM system properties.
applyTransformers(MuleEvent, List<? extends Transformer>) - Method in interface org.mule.api.MuleMessage
Will apply a list of transformers to the payload of the message.
applyTransformers(MuleEvent, Transformer...) - Method in interface org.mule.api.MuleMessage
Will apply a list of transformers to the payload of the message.
applyTransformers(MuleEvent, List<? extends Transformer>, Class<?>) - Method in interface org.mule.api.MuleMessage
Will apply a list of transformers to the payload of the message.
applyTransformers(MuleEvent, List<? extends Transformer>) - Method in class org.mule.DefaultMuleMessage
Will apply a list of transformers to the payload of the message.
applyTransformers(MuleEvent, Transformer...) - Method in class org.mule.DefaultMuleMessage
Will apply a list of transformers to the payload of the message.
applyTransformers(MuleEvent, List<? extends Transformer>, Class<?>) - Method in class org.mule.DefaultMuleMessage
 
applyVendorSpecificConnectionFactoryProperties(ConnectionFactory) - Method in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
appName - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
appsDir - Variable in class org.mule.module.launcher.DeploymentService.AppDirWatcher
 
arguments - Variable in class org.mule.expression.transformers.AbstractExpressionTransformer
 
arguments - Variable in class org.mule.processor.InvokerMessageProcessor
 
argumentTypes - Variable in class org.mule.processor.InvokerMessageProcessor
 
array2List(E[]) - Static method in class org.mule.transport.http.multipart.LazyList
 
ArrayEntryPointResolver - Class in org.mule.model.resolvers
Will resolver entry point methods on a service service that accept a single array.
ArrayEntryPointResolver() - Constructor for class org.mule.model.resolvers.ArrayEntryPointResolver
 
ArrayMessageSequence - Class in org.mule.routing.outbound
 
ArrayMessageSequence(Object[]) - Constructor for class org.mule.routing.outbound.ArrayMessageSequence
 
ArrayUtils - Class in org.mule.util
 
ArrayUtils() - Constructor for class org.mule.util.ArrayUtils
 
asArrayOfCookies(Object) - Static method in class org.mule.transport.http.CookieHelper
Returns an array view of the cookiesObject.
assertAccess(boolean) - Method in interface org.mule.api.ThreadSafeAccess
This method may be called before data in the object are accessed.
assertAccess(boolean) - Method in class org.mule.DefaultMuleEvent
 
assertAccess(boolean) - Method in class org.mule.DefaultMuleMessage
This method may be called before data in the object are accessed.
assertAddressConsistent() - Method in class org.mule.endpoint.URIBuilder
 
assertArgument(boolean, String) - Method in class org.mule.module.xml.config.XsltTextDefinitionParser
 
assertEvent(Rules, Object, String) - Method in interface org.mule.module.bpm.RulesEngine
Add an event to the event stream.
assertEvent(Rules, Object, String) - Method in class org.mule.module.drools.Drools
 
assertFact(Rules, Object) - Method in interface org.mule.module.bpm.RulesEngine
Assert a fact in the knowledge base.
assertFact(Rules, Object) - Method in class org.mule.module.drools.Drools
 
AssertionMessageProcessor - Class in org.mule.tck.functional
 
AssertionMessageProcessor() - Constructor for class org.mule.tck.functional.AssertionMessageProcessor
 
assertMuleParent(Element) - Method in class org.mule.config.spring.parsers.generic.MuleOrphanDefinitionParser
 
assertNotUsed() - Method in class org.mule.endpoint.URIBuilder
 
assertProtocolConsistent() - Method in class org.mule.endpoint.URIBuilder
 
assertTargetPresent() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
assignValue(String, T, T) - Method in interface org.mule.api.el.VariableAssignmentCallback
 
associateConnection(MuleManagedConnection) - Method in class org.mule.module.jca.DefaultMuleConnection
Associates connection handle with new managed connection.
associateConnection(MuleManagedConnection) - Method in interface org.mule.module.jca.MuleConnection
 
associateConnection(Object) - Method in class org.mule.module.jca.MuleManagedConnection
Used by the container to change the association of an application-level connection handle with a ManagedConnection instance.
assureReady() - Method in class org.mule.util.xa.AbstractResourceManager
Check that the FileManager is ready.
assureStarted() - Method in class org.mule.util.xa.AbstractResourceManager
Check that the FileManager is started.
async(MuleContext, String, int) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
ASYNC_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
ASYNC_REPLY_TIMEOUT - Static variable in class org.mule.context.notification.RoutingNotification
 
AsyncDelegateMessageProcessor - Class in org.mule.processor
Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of MessageProcessor delegate configured the next MessageProcessor.
AsyncDelegateMessageProcessor(MessageProcessor, ProcessingStrategy, String) - Constructor for class org.mule.processor.AsyncDelegateMessageProcessor
 
asyncDoesNotSupportTransactions() - Static method in class org.mule.config.i18n.CoreMessages
 
asynchronous - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Determines whether events will be processed asynchronously
AsynchronousEventListener - Class in org.mule.module.spring.events
AsynchronousEventListener will proces a received MuleEvent in a separate Thread.
AsynchronousEventListener(ExecutorService, ApplicationListener) - Constructor for class org.mule.module.spring.events.AsynchronousEventListener
 
AsynchronousLoanBroker - Class in org.mule.example.loanbroker
LoanBroker is the Service that starts the loan request process.
AsynchronousLoanBroker() - Constructor for class org.mule.example.loanbroker.AsynchronousLoanBroker
 
AsynchronousProcessingStrategy - Class in org.mule.processor.strategy
This strategy uses a WorkManager to schedule the processing of the pipeline of message processors in a single worker thread.
AsynchronousProcessingStrategy() - Constructor for class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
AsynchronousRetryTemplate - Class in org.mule.retry.async
This class is a wrapper for a RetryPolicyTemplate and will execute any retry work within a separate thread.
AsynchronousRetryTemplate(RetryPolicyTemplate) - Constructor for class org.mule.retry.async.AsynchronousRetryTemplate
 
AsyncInterceptingMessageProcessor - Class in org.mule.processor
Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
AsyncInterceptingMessageProcessor(WorkManagerSource) - Constructor for class org.mule.processor.AsyncInterceptingMessageProcessor
 
AsyncInterceptingMessageProcessor(ThreadingProfile, String, int) - Constructor for class org.mule.processor.AsyncInterceptingMessageProcessor
 
AsyncMessageProcessorsDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
AsyncMessageProcessorsDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.AsyncMessageProcessorsDefinitionParser
 
AsyncMessageProcessorsFactoryBean - Class in org.mule.config.spring.factories
 
AsyncMessageProcessorsFactoryBean() - Constructor for class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
asyncPool - Variable in class org.mule.module.spring.events.MuleEventMulticaster
An ExecutorService for handling asynchronous events
asyncReceiveRemote(String, int) - Method in class org.mule.module.client.RemoteDispatcher
 
asyncReplyMessageSource - Variable in class org.mule.service.AbstractService
 
AsyncReplyToPropertyRequestReplyReplier - Class in org.mule.routing.requestreply
 
AsyncReplyToPropertyRequestReplyReplier() - Constructor for class org.mule.routing.requestreply.AsyncReplyToPropertyRequestReplyReplier
 
AsyncWorkListener - Class in org.mule.processor
 
AsyncWorkListener(MessageProcessor) - Constructor for class org.mule.processor.AsyncWorkListener
 
ATOM - Static variable in interface org.mule.transformer.types.MimeTypes
 
ATOM_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
AtomEntryBuilderTransformer - Class in org.mule.module.atom.transformers
 
AtomEntryBuilderTransformer() - Constructor for class org.mule.module.atom.transformers.AtomEntryBuilderTransformer
 
AtomNamespaceHandler - Class in org.mule.module.atom.config
 
AtomNamespaceHandler() - Constructor for class org.mule.module.atom.config.AtomNamespaceHandler
 
ATTACHMENT_HEADERS_PROPERTY_POSTFIX - Static variable in class org.mule.transport.email.AbstractMailConnector
 
AttachmentExpressionEnricher - Class in org.mule.expression
 
AttachmentExpressionEnricher() - Constructor for class org.mule.expression.AttachmentExpressionEnricher
 
ATTACHMENTS - Static variable in class org.mule.module.cxf.CxfConstants
 
attemptFileLock(File) - Method in class org.mule.transport.file.FileMessageReceiver
Try to acquire a lock on a file and release it immediately.
ATTR_JAVAX_SERVLET_CONTEXT_TEMPDIR - Static variable in class org.mule.config.builders.MuleXmlBuilderContextListener
Name of the temp dir param as per the servlet spec.
ATTRIBUTE_CLASS - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_ID - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_ID - Static variable in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.InterceptorStackDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
ATTRIBUTE_OBJECT_CLASS - Static variable in class org.mule.object.AbstractObjectFactory
 
ATTRIBUTE_OBJECT_CLASS_NAME - Static variable in class org.mule.object.AbstractObjectFactory
 
ATTRIBUTE_REF - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REF_SUFFIX - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REFS - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REFS_SUFFIX - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
AttributeConcatenation - Class in org.mule.config.spring.parsers.processors
 
AttributeConcatenation(String, String, String[]) - Constructor for class org.mule.config.spring.parsers.processors.AttributeConcatenation
 
AttributeEvaluator - Class in org.mule.util
This class acts as a wrapper for configuration attributes that support simple text, expression or regular expressions.
AttributeEvaluator(String) - Constructor for class org.mule.util.AttributeEvaluator
 
AttributeListEntryDefinitionParser - Class in org.mule.config.spring.parsers.collection
 
AttributeListEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
Only for use with dynamic naming
AttributeListEntryDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
AttributeMapBeanAssembler - Class in org.mule.config.spring.parsers.assembly
This can be used inside a ChildDefinitionParser - it takes named properties and, instead of inserting them individually on the target, it packages them as a Map and inserts that.
AttributeMapBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Constructor for class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssembler
 
AttributeMapBeanAssemblerFactory - Class in org.mule.config.spring.parsers.assembly
 
AttributeMapBeanAssemblerFactory() - Constructor for class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssemblerFactory
 
AttributeMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single, stand-alone map object and processes all attributes to this map
AttributeMapDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeMapDefinitionParser
 
attributeName - Variable in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
attributeName(Attr) - Static method in class org.mule.util.XMLUtils
 
attributeNameToPropertyName(String) - Static method in class org.mule.config.spring.parsers.assembly.configuration.Conventions
Overloads the Spring version of this method to tak into account the first character in the attribute name An upper case char as the first letter of a bean name is not allowed.
AttributePropertiesDefinitionParser - Class in org.mule.config.spring.parsers.generic
 
AttributePropertiesDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.AttributePropertiesDefinitionParser
 
AttributePropertiesDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.generic.AttributePropertiesDefinitionParser
 
AttributeSelectionDefinitionParser - Class in org.mule.config.spring.parsers.delegate
Select sub parser depending on presence of a particular attribute
AttributeSelectionDefinitionParser(String, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.AttributeSelectionDefinitionParser
 
authDeniedOnEndpoint(URI) - Static method in class org.mule.config.i18n.CoreMessages
 
authDeniedOnEndpoint(Object) - Static method in class org.mule.module.jca.i18n.JcaMessages
 
authEndpointMustSendOrReceive() - Static method in class org.mule.config.i18n.CoreMessages
 
authenticate(MuleEvent) - Method in interface org.mule.api.security.AuthenticationFilter
 
authenticate(Authentication) - Method in interface org.mule.api.security.SecurityManager
 
authenticate(Authentication) - Method in interface org.mule.api.security.SecurityProvider
 
authenticate(MuleEvent) - Method in class org.mule.example.notifications.DummySecurityFilter
 
authenticate(Authentication) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
The authenticate method first creates the jaas Login Context using the callback handler and the name of the class or directory to prtect.
authenticate(Object) - Method in class org.mule.module.management.support.SimplePasswordJmxAuthenticator
 
authenticate(Authentication) - Method in class org.mule.module.pgp.PGPSecurityProvider
 
authenticate(Authentication) - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
authenticate(Authentication) - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
authenticate(MuleEvent) - Method in class org.mule.security.AbstractAuthenticationFilter
 
authenticate(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.  
authenticate(Authentication) - Method in class org.mule.security.MuleSecurityManager
 
authenticate(MuleEvent) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
Authenticates the current message.
authenticate(Authentication) - Method in class org.mule.tck.security.TestMultiuserSecurityProvider
 
authenticate(Authentication) - Method in class org.mule.tck.security.TestSingleUserSecurityProvider
 
authenticate(Credentials, HttpMethod) - Method in class org.mule.transport.http.ntlm.NTLMScheme
 
authenticate(Credentials, String, String) - Method in class org.mule.transport.http.ntlm.NTLMScheme
 
authenticateInbound(MuleEvent) - Method in class org.mule.module.jaas.filters.JaasSecurityFilter
 
authenticateInbound(MuleEvent) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
authenticateInbound(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.  
authenticateInbound(MuleEvent) - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
authenticateInbound(MuleEvent) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
Authenticates the current message if authenticate is set to true.
authenticateOutbound(MuleEvent) - Method in class org.mule.module.jaas.filters.JaasSecurityFilter
 
authenticateOutbound(MuleEvent) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
authenticateOutbound(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.  
authenticateOutbound(MuleEvent) - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
authenticateOutbound(MuleEvent) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
Authenticates the current message if authenticate is set to true.
Authentication - Interface in org.mule.api.security
Authentication represents an authentication request and contains authentication information if the request was successful
AuthenticationFilter - Interface in org.mule.api.security
AuthenticationFilter is a base filter for authenticating messages.
authFailedForUser(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
authNoCredentials() - Static method in class org.mule.config.i18n.CoreMessages
 
authNoEncryptionStrategy(String) - Static method in class org.mule.config.i18n.CoreMessages
 
authNoSecurityProvider(String) - Static method in class org.mule.config.i18n.CoreMessages
 
authorizationAttemptFailed() - Static method in class org.mule.config.i18n.CoreMessages
 
authorizationDeniedOnEndpoint(URI) - Static method in class org.mule.config.i18n.CoreMessages
 
AuthorizationFilter - Class in org.mule.module.spring.security
Authorizes user access based on the required authorities for a user.
AuthorizationFilter() - Constructor for class org.mule.module.spring.security.AuthorizationFilter
 
authRealmMustBeSetOnFilter() - Static method in class org.mule.module.spring.security.i18n.SpringSecurityMessages
 
authRealmMustBeSetOnFilter() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
authSecurityManagerNotSet() - Static method in class org.mule.config.i18n.CoreMessages
 
authSetButNoContext(String) - Static method in class org.mule.config.i18n.CoreMessages
 
authTypeNotRecognised(String) - Static method in class org.mule.config.i18n.CoreMessages
 
AUTO_ACK_COUNT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
AutoConfigurationBuilder - Class in org.mule.config.builders
Configures Mule from a configuration resource or comma seperated list of configuration resources by auto-detecting the ConfigurationBuilder to use for each resource.
AutoConfigurationBuilder(String) - Constructor for class org.mule.config.builders.AutoConfigurationBuilder
 
AutoConfigurationBuilder(String[]) - Constructor for class org.mule.config.builders.AutoConfigurationBuilder
 
AutoConfigurationBuilder(ConfigResource[]) - Constructor for class org.mule.config.builders.AutoConfigurationBuilder
 
autoConfigure(MuleContext, ConfigResource[]) - Method in class org.mule.config.builders.AutoConfigurationBuilder
 
AutoDiscoveryJmxSupportFactory - Class in org.mule.module.management.support
Will discover if newer JMX version is available, otherwise fallback to JMX 1.1 style support.
AutoDiscoveryJmxSupportFactory() - Constructor for class org.mule.module.management.support.AutoDiscoveryJmxSupportFactory
Constructs a new AutoDiscoveryJmxSupportFactory.
AutoDiscoveryRedeliveryHandlerFactory - Class in org.mule.transport.jms.redelivery
This factory will consult JMS connection metadata for supported optional properties and use those, if available, otherwise falling back to the manual counting of redeliveries.
AutoDiscoveryRedeliveryHandlerFactory(JmsConnector) - Constructor for class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
AutoDiscoverySecurityProviderFactory - Class in org.mule.api.security.provider
Automatically discovers the JDK we are running on and returns a corresponding SecurityProviderInfo.
AutoDiscoverySecurityProviderFactory() - Constructor for class org.mule.api.security.provider.AutoDiscoverySecurityProviderFactory
 
AutoIdUtils - Class in org.mule.config.spring.parsers.generic
 
AutoIdUtils() - Constructor for class org.mule.config.spring.parsers.generic.AutoIdUtils
 
autoResolveVariables - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
AutoTransformer - Class in org.mule.transformer.simple
A transformer that uses the transform discovery mechanism to convert the message payload.
AutoTransformer() - Constructor for class org.mule.transformer.simple.AutoTransformer
 
available(int) - Static method in class org.apache.maven.enforcer.rule.EnforcerPortRule
Check port availability.
available() - Method in class org.mule.model.streaming.DelegatingInputStream
 
available() - Method in class org.mule.module.pgp.LazyTransformedInputStream
 
AVERAGE - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the average value of a counter
Average - Class in org.mule.util.counters.impl
 
Average(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.Average
 
await() - Method in class org.mule.tck.concurrency.TestingThread
Block until the thread completes its doRun() method.
await(long) - Method in class org.mule.tck.functional.CountdownCallback
 
AWAIT_TIMEOUT - Static variable in class org.mule.tck.concurrency.TestingThread
 
AXIS - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
AXIS_CLIENT_CONFIG_PROPERTY - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
AXIS_OPTIONS - Static variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
AXIS_SERVICE_COMPONENT_NAME - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
AXIS_SERVICE_PROPERTY - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
AxisCleanAndAddProperties - Class in org.mule.transport.soap.axis.extras
 
AxisCleanAndAddProperties() - Constructor for class org.mule.transport.soap.axis.extras.AxisCleanAndAddProperties
 
AxisConnector - Class in org.mule.transport.soap.axis
AxisConnector is used to maintain one or more Services for Axis server instance.
AxisConnector(MuleContext) - Constructor for class org.mule.transport.soap.axis.AxisConnector
 
AxisFaultExceptionReader - Class in org.mule.transport.soap.axis
Will format and display additional information stored with an Axis fault that is usually hidden when logged.
AxisFaultExceptionReader() - Constructor for class org.mule.transport.soap.axis.AxisFaultExceptionReader
 
AxisInitialisable - Interface in org.mule.transport.soap.axis
AxisInitialisable can be implemented by a Mule component that will be used as an Axis service to customise the Axis Service object
AxisInitialisationCallback - Class in org.mule.transport.soap.axis
AxisInitialisationCallback is invoked when an Axis component is created from its descriptor.
AxisInitialisationCallback(SOAPService) - Constructor for class org.mule.transport.soap.axis.AxisInitialisationCallback
 
AxisMessageDispatcher - Class in org.mule.transport.soap.axis
AxisMessageDispatcher is used to make soap requests via the Axis soap client.
AxisMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.soap.axis.AxisMessageDispatcher
 
AxisMessageDispatcherFactory - Class in org.mule.transport.soap.axis
AxisMessageDispatcherFactory creates an AxisMessageDispatcher, used for making SOAP calls using the Axis stack.
AxisMessageDispatcherFactory() - Constructor for class org.mule.transport.soap.axis.AxisMessageDispatcherFactory
 
AxisMessageReceiver - Class in org.mule.transport.soap.axis
AxisMessageReceiver is used to register a component as a service with a Axis server.
AxisMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.soap.axis.AxisMessageReceiver
 
AxisMessageRequester - Class in org.mule.transport.soap.axis
AxisMessageDispatcher is used to make soap requests via the Axis soap client.
AxisMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.soap.axis.AxisMessageRequester
 
AxisMessageRequesterFactory - Class in org.mule.transport.soap.axis
AxisMessageRequesterFactory creates an AxisMessageRequester, used for making SOAP calls using the Axis stack.
AxisMessageRequesterFactory() - Constructor for class org.mule.transport.soap.axis.AxisMessageRequesterFactory
 
AxisMessages - Class in org.mule.transport.soap.axis.i18n
 
AxisMessages() - Constructor for class org.mule.transport.soap.axis.i18n.AxisMessages
 
AxisMuleMessageFactory - Class in org.mule.transport.soap.axis
 
AxisMuleMessageFactory(MuleContext) - Constructor for class org.mule.transport.soap.axis.AxisMuleMessageFactory
 
AxisMuleSession - Class in org.mule.transport.soap.axis.extensions
Provides an adapter to a DefaultMuleSession so that Axis can write to the session
AxisMuleSession(MuleSession) - Constructor for class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
AxisNamespaceHandler - Class in org.mule.transport.soap.axis.config
Registers a Bean Definition Parser for handling <axis:connector> elements.
AxisNamespaceHandler() - Constructor for class org.mule.transport.soap.axis.config.AxisNamespaceHandler
 
AxisServiceComponent - Class in org.mule.transport.soap.axis
AxisServiceComponent is a Mule component implementation of the Axis servlet.
AxisServiceComponent() - Constructor for class org.mule.transport.soap.axis.AxisServiceComponent
For IoC
AxisServiceProxy - Class in org.mule.transport.soap.axis
ServiceProxy is a proxy that wraps a soap endpointUri to look like a Web service.
AxisServiceProxy() - Constructor for class org.mule.transport.soap.axis.AxisServiceProxy
 
AxisStringWriter - Class in org.mule.transport.soap.axis
AxisStringWriter wraps a java.io.StringWriter and allows meta information to be associated with it.
AxisStringWriter() - Constructor for class org.mule.transport.soap.axis.AxisStringWriter
 
AxisWsdlConnector - Class in org.mule.transport.soap.axis.wsdl
TODO document
AxisWsdlConnector(MuleContext) - Constructor for class org.mule.transport.soap.axis.wsdl.AxisWsdlConnector
 
AxisWsdlMessageDispatcher - Class in org.mule.transport.soap.axis.wsdl
Creates and Axis client services from WSDL and invokes it.
AxisWsdlMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.soap.axis.wsdl.AxisWsdlMessageDispatcher
 
AxisWsdlMessageDispatcherFactory - Class in org.mule.transport.soap.axis.wsdl
Creates an WSDL Message dispatcher using the Axis client
AxisWsdlMessageDispatcherFactory() - Constructor for class org.mule.transport.soap.axis.wsdl.AxisWsdlMessageDispatcherFactory
 

B

Bank - Class in org.mule.example.loanbroker.bank
Bank is a representation of a bank from which to obtain loan quotes.
Bank() - Constructor for class org.mule.example.loanbroker.bank.Bank
 
BankQuotesAggregationLogic - Class in org.mule.example.loanbroker.routers
 
BankQuotesAggregationLogic() - Constructor for class org.mule.example.loanbroker.routers.BankQuotesAggregationLogic
 
BankQuotesInboundAggregator - Class in org.mule.example.loanbroker.routers
BankQuotesInboundAggregator receives a number of quotes and selects the lowest
BankQuotesInboundAggregator() - Constructor for class org.mule.example.loanbroker.routers.BankQuotesInboundAggregator
 
BankQuotesResponseAggregator - Class in org.mule.example.loanbroker.routers
BankQuotesInboundAggregator receives a number of quotes and selects the lowest
BankQuotesResponseAggregator() - Constructor for class org.mule.example.loanbroker.routers.BankQuotesResponseAggregator
 
BankService - Interface in org.mule.example.loanbroker.bank
BankService is a representation of a bank form which to obtain loan quotes.
Base64 - Class in org.mule.util
 
Base64.InputStream - Class in org.mule.util
A Base64.InputStream will read data from another InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.InputStream(InputStream) - Constructor for class org.mule.util.Base64.InputStream
Constructs a Base64.InputStream in DECODE mode.
Base64.InputStream(InputStream, int) - Constructor for class org.mule.util.Base64.InputStream
Constructs a Base64.InputStream in either ENCODE or DECODE mode.
Base64.OutputStream - Class in org.mule.util
A Base64.OutputStream will write data to another OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.OutputStream(OutputStream) - Constructor for class org.mule.util.Base64.OutputStream
Constructs a Base64.OutputStream in ENCODE mode.
Base64.OutputStream(OutputStream, int) - Constructor for class org.mule.util.Base64.OutputStream
Constructs a Base64.OutputStream in either ENCODE or DECODE mode.
Base64Decoder - Class in org.mule.transformer.codec
Base64Encoder transforms Base64 encoded data into strings or byte arrays.
Base64Decoder() - Constructor for class org.mule.transformer.codec.Base64Decoder
 
Base64Encoder - Class in org.mule.transformer.codec
Base64Encoder transforms strings or byte arrays into Base64 encoded string.
Base64Encoder() - Constructor for class org.mule.transformer.codec.Base64Encoder
 
base64Encoding - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
BaseAttachmentExpressionEvaluator - Class in org.mule.expression
 
BaseAttachmentExpressionEvaluator() - Constructor for class org.mule.expression.BaseAttachmentExpressionEvaluator
 
basepackages - Variable in class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
basepath - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
 
BaseToOutputHandler - Class in org.mule.module.atom.transformers
Converts Abdera model elements which extend Base to OutputHandlers.
BaseToOutputHandler() - Constructor for class org.mule.module.atom.transformers.BaseToOutputHandler
 
basicFilterCannotHandleHeader(String) - Static method in class org.mule.module.spring.security.i18n.SpringSecurityMessages
 
basicFilterCannotHandleHeader(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
basicListFiles(File, List<File>) - Method in class org.mule.transport.file.FileMessageReceiver
 
BatchConstraint - Class in org.mule.transaction.constraints
BatchConstraint is a filter that counts on every execution and returns true when the batch size value equals the execution count.
BatchConstraint() - Constructor for class org.mule.transaction.constraints.BatchConstraint
 
batchSize - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
bayeux - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
bayeux - Variable in class org.mule.transport.ajax.container.AjaxServletConnector
 
BayeuxAware - Interface in org.mule.transport.ajax
Set on objects that have or need access to the Bayeux CometD object
BCC_ADDRESSES_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
bean - Variable in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
BEAN_TYPES - Static variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
BeanAssembler - Interface in org.mule.config.spring.parsers.assembly
Bean Assembler provides a high-level interface to constructing beans.
BeanAssemblerFactory - Interface in org.mule.config.spring.parsers.assembly
 
BeanBuilderTransformer - Class in org.mule.expression.transformers
This transformer uses the returnClass to create the return object and then will populate the bean with arguments defined as expressions
BeanBuilderTransformer() - Constructor for class org.mule.expression.transformers.BeanBuilderTransformer
 
beanClass - Variable in class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
beanNotInstanceOfApplicationListener(String) - Static method in class org.mule.module.spring.i18n.SpringMessages
 
BeanPayloadExpressionEvaluator - Class in org.mule.module.xml.expression
TODO
BeanPayloadExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
 
beanPropertyConfiguration - Variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
BEANS - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
BeanToMap - Class in org.mule.transformer.simple
Conversts a simple bean object to a Map.
BeanToMap() - Constructor for class org.mule.transformer.simple.BeanToMap
 
BeanUtils - Class in org.mule.util
BeanUtils provides functions for altering the way commons BeanUtils works
BeanUtils() - Constructor for class org.mule.util.BeanUtils
 
before(MuleEvent) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
This method is invoked before the event is processed
before(MuleEvent) - Method in class org.mule.interceptor.LoggingInterceptor
 
before(MuleEvent) - Method in class org.mule.interceptor.ProcessingTimeInterceptor
 
beforeRouting(Exception, MuleEvent) - Method in class org.mule.exception.CatchMessagingExceptionStrategy
 
beforeRouting(Exception, MuleEvent) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
beforeRouting(Exception, MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
begin() - Method in interface org.mule.api.transaction.Transaction
Begin the transaction.
begin() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
begin() - Method in class org.mule.transaction.AbstractTransaction
 
begin() - Method in interface org.mule.util.queue.QueueSession
 
begin() - Method in class org.mule.util.xa.DefaultXASession
 
beginTransaction(MuleContext) - Method in interface org.mule.api.transaction.TransactionFactory
Create and begins a new transaction
beginTransaction(MuleContext) - Method in class org.mule.module.spring.transaction.SpringTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.processor.DelegateTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.transaction.XaTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.transport.jdbc.JdbcTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.transport.jms.JmsTransactionFactory
 
beginTransaction(MuleContext) - Method in class org.mule.transport.vm.VMTransactionFactory
 
beginTransaction(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
bestGuessName(PropertyConfiguration, String, String) - Static method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
BINARY - Static variable in interface org.mule.transformer.types.MimeTypes
 
bind(Name, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
bind(String, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
bind(Name, Object) - Method in class org.mule.jndi.SimpleContext
 
bind(String, Object) - Method in class org.mule.jndi.SimpleContext
 
bind(Name, Object) - Method in class org.mule.tck.jndi.InMemoryContext
 
bind(String, Object) - Method in class org.mule.tck.jndi.InMemoryContext
 
bindDocument(Object, XQPreparedExpression) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Returns the InputSource corresponding to xqueryFile or xquery
BindingDefinitionParser - Class in org.mule.config.spring.parsers.specific
Binding definition parser for parsing all binding elements configured as part of the service.
BindingDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.BindingDefinitionParser
 
BindingDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.BindingDefinitionParser
 
BindingInvocationHandler - Class in org.mule.component
 
BindingInvocationHandler(InterfaceBinding) - Constructor for class org.mule.component.BindingInvocationHandler
 
bindings - Variable in class org.mule.component.AbstractJavaComponent
 
bindings - Variable in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
bindings - Variable in class org.mule.jndi.SimpleContext
What holds the bindings.
bindings - Variable in class org.mule.module.scripting.component.ScriptComponent
 
BindingUtils - Class in org.mule.component
 
BindingUtils() - Constructor for class org.mule.component.BindingUtils
 
bindParameters(XQPreparedExpression, MuleMessage) - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
bindResource(Object, Object) - Method in interface org.mule.api.transaction.Transaction
 
bindResource(Object, Object) - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
bindResource(Object, Object) - Method in class org.mule.processor.DelegateTransaction
 
bindResource(Object, Object) - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
bindResource(Object, Object) - Method in class org.mule.transaction.XaTransaction
 
bindResource(Object, Object) - Method in class org.mule.transport.jdbc.JdbcTransaction
 
bindResource(Object, Object) - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
bindResource(Object, Object) - Method in class org.mule.transport.jms.JmsTransaction
 
bindResource(Object, Object) - Method in class org.mule.transport.vm.VMTransaction
 
bindTransaction(Transaction) - Method in class org.mule.transaction.TransactionCoordination
 
bindTransaction(Transaction) - Method in class org.mule.transport.AbstractReceiverWorker
Template method used to bind the resources of this receiver to the transaction.
bindTransaction(Transaction) - Method in class org.mule.transport.jms.JmsMessageReceiver.JmsWorker
Deprecated.  
bindTransaction(Transaction) - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.JmsWorker
 
bindTransaction(Transaction) - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
bindUserTransaction() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.DummyJndiConfiguration
 
bindXaResourceIfRequired() - Method in class org.mule.transport.vm.VMConnector
 
blankAttribute(Element, String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
BlockAttribute - Class in org.mule.config.spring.parsers.processors
Throws an exception if any of the disallowed attributes (after translation) is present.
BlockAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.BlockAttribute
 
BlockAttribute(String[]) - Constructor for class org.mule.config.spring.parsers.processors.BlockAttribute
 
BlockAttribute.BlockAttributeException - Exception in org.mule.config.spring.parsers.processors
 
blocked - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
BlockingServerEvent - Interface in org.mule.api.context.notification
BlockingServerEvent is a marker interface that tells the server event manager to publish this event in the current thread, thus blocking the current thread of execution until all listeners have been processed
BobberArchetype - Class in com.javaforge.bobber.archetype.model
Describes the assembly layout and packaging.
BobberArchetype() - Constructor for class com.javaforge.bobber.archetype.model.BobberArchetype
 
BobberArchetype - Class in com.javaforge.bobber.plugin.archetype
 
BobberArchetype() - Constructor for class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
BobberArchetypeMojo - Class in org.apache.maven.plugin.archetype
Builds archetype containers.
BobberArchetypeMojo() - Constructor for class org.apache.maven.plugin.archetype.BobberArchetypeMojo
 
BobberArchetypeXpp3Reader - Class in com.javaforge.bobber.archetype.model.io.xpp3
Class BobberArchetypeXpp3Reader.
BobberArchetypeXpp3Reader() - Constructor for class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
 
BobberArchetypeXpp3Writer - Class in com.javaforge.bobber.archetype.model.io.xpp3
Class BobberArchetypeXpp3Writer.
BobberArchetypeXpp3Writer() - Constructor for class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Writer
 
body - Variable in class org.mule.util.SplashScreen
 
boilerPlate(String) - Method in class org.mule.util.MuleLogger
 
boilerPlate(String, char, int) - Method in class org.mule.util.MuleLogger
 
boilerPlate(List, char, int) - Method in class org.mule.util.MuleLogger
 
boilerPlate(String[], char, int) - Method in class org.mule.util.MuleLogger
 
Book - Class in org.mule.example.bookstore
Simple class which represents a Book in the catalog of the bookstore.
Book() - Constructor for class org.mule.example.bookstore.Book
 
Book(String, String, double) - Constructor for class org.mule.example.bookstore.Book
 
BookstoreAdminMessages - Class in org.mule.example.bookstore
 
BookstoreAdminMessages() - Constructor for class org.mule.example.bookstore.BookstoreAdminMessages
 
BooleanAttributeSelectionDefinitionParser - Class in org.mule.config.spring.parsers.delegate
 
BooleanAttributeSelectionDefinitionParser(String, boolean, MuleDefinitionParser, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.BooleanAttributeSelectionDefinitionParser
 
bootstrapContext - Variable in class org.mule.module.jca.MuleResourceAdapter
 
BootstrapObjectFactory - Interface in org.mule.config.bootstrap
A simple factory interface that can be listed in a registry-bootstrap.properties file
borrowComponentLifecycleAdaptor() - Method in class org.mule.component.AbstractJavaComponent
 
borrowComponentLifecycleAdaptor() - Method in class org.mule.component.DefaultJavaComponent
 
borrowComponentLifecycleAdaptor() - Method in class org.mule.component.PooledJavaComponent
 
borrowComponentLifecycleAdaptor() - Method in class org.mule.component.SimpleCallableJavaComponent
 
borrowComponentLifecycleAdaptor() - Method in class org.mule.module.jca.JcaComponent
 
borrowObject(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
borrowObject() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
borrowObject() - Method in interface org.mule.util.pool.ObjectPool
 
bothServiceClassAndWsdlUrlAreRequired() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
BPM_PROPERTY_PREFIX - Static variable in class org.mule.module.bpm.Process
 
BpmNamespaceHandler - Class in org.mule.module.bpm.config
Registers a Bean Definition Parsers for the "bpm" namespace.
BpmNamespaceHandler() - Constructor for class org.mule.module.bpm.config.BpmNamespaceHandler
 
BPMS - Interface in org.mule.module.bpm
A generic interface for any Process Engine.
bpms - Variable in class org.mule.module.bpm.ProcessComponent
The underlying BPMS
breakVariableAssociation(Variable) - Method in class com.javaforge.bobber.archetype.model.Variable
Method breakVariableAssociation.
Bridge - Class in org.mule.construct
A simple bridge between a single inbound endpoint and a single outbound endpoint.
Bridge(String, MuleContext, MessageSource, OutboundEndpoint, List<MessageProcessor>, List<MessageProcessor>, MessageExchangePattern, boolean) - Constructor for class org.mule.construct.Bridge
 
bridge() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
BridgeBuilder - Class in org.mule.construct.builder
 
BridgeBuilder() - Constructor for class org.mule.construct.builder.BridgeBuilder
 
BridgeDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
BridgeDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.BridgeDefinitionParser
 
BridgeFactoryBean - Class in org.mule.config.spring.factories
 
BridgeFactoryBean() - Constructor for class org.mule.config.spring.factories.BridgeFactoryBean
 
broadcast - Variable in class org.mule.transport.udp.UdpConnector
 
BROADCASTER_JMX_OBJECT_NAME - Static variable in class org.mule.module.management.agent.JmxServerNotificationAgent
 
BUFFER_OUTPUT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
bufferSize - Variable in class org.mule.transport.tcp.protocols.DirectProtocol
 
bufferSize - Variable in class org.mule.transport.udp.UdpMessageReceiver
 
build(URI, MuleContext) - Method in interface org.mule.api.endpoint.EndpointURIBuilder
 
build() - Method in interface org.mule.api.processor.MessageProcessorBuilder
 
build(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
build(URI, MuleContext) - Method in class org.mule.endpoint.AbstractEndpointURIBuilder
 
build() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
build() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
build() - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
This builder supports the chaining together of message processors that intercept and also those that don't.
buildAndRegister(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
Builder<T> - Interface in org.mule.config.dsl
TODO
BuildersMessages - Class in org.mule.config.builders.i18n
 
BuildersMessages() - Constructor for class org.mule.config.builders.i18n.BuildersMessages
 
buildFailureResponse(HttpVersion, int, String) - Method in class org.mule.transport.http.HttpMessageReceiver.HttpWorker
 
buildFlowConstruct(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
buildFlowConstruct(MuleContext) - Method in class org.mule.construct.builder.BridgeBuilder
 
buildFlowConstruct(MuleContext) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
buildFlowConstruct(MuleContext) - Method in class org.mule.construct.builder.ValidatorBuilder
 
buildFlowConstruct(MuleContext) - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
buildFlowConstruct(MuleContext) - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
buildFullyQualifiedEndpointName(EndpointServiceMBean, Connector) - Method in class org.mule.module.management.agent.JmxAgent
 
buildInboundEndpoint() - Method in interface org.mule.api.endpoint.EndpointBuilder
Constructs inbound endpoints
buildInboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
buildInboundEndpoint() - Method in class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
buildInboundEndpoint() - Method in class org.mule.module.cxf.endpoint.WsdlCxfEndpointBuilder
 
buildMuleContext() - Method in interface org.mule.api.context.MuleContextBuilder
Builds a new MuleContext instance using configured builder instance.
buildMuleContext() - Method in class org.mule.context.DefaultMuleContextBuilder
Builds a new MuleContext instance using configured builder instance.
buildMuleContext(MuleContextBuilder) - Method in class org.mule.context.DefaultMuleContextFactory
 
buildOutboundEndpoint() - Method in interface org.mule.api.endpoint.EndpointBuilder
Constructs outbound endpoints
buildOutboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
buildOutboundEndpoint() - Method in class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
buildOutboundEndpoint() - Method in class org.mule.module.cxf.endpoint.WsdlCxfEndpointBuilder
 
buildOutboundEndpoint(String) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
buildQueueKey(MuleEvent) - Static method in class org.mule.routing.UntilSuccessful
 
buildResponseMessage(MuleEvent, MuleEvent, Object[]) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
buildScheduler() - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
buildServiceMessageProcessorChain() - Method in class org.mule.service.AbstractService
 
buildShutdownSplash() - Method in class org.mule.DefaultMuleContext
 
buildSoapMethods(MuleEvent, Call, Object, String, Object[]) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
buildStartupSplash() - Method in class org.mule.DefaultMuleContext
 
bus - Variable in class org.mule.module.cxf.CxfInboundMessageProcessor
 
BUS_PROPERTY - Static variable in class org.mule.module.cxf.CxfConfiguration
 
BusinessErrorManager - Class in org.mule.example.errorhandler
The BusinessErrorManager is a Service that processes exceptions of type org.mule.example.errorhandler.exceptions.BusinessException.
BusinessErrorManager() - Constructor for class org.mule.example.errorhandler.BusinessErrorManager
 
businessErrorManagerError() - Static method in class org.mule.example.errorhandler.LocaleMessage
 
BusinessException - Exception in org.mule.example.errorhandler.exceptions
BusinessException TODO (document class)
BusinessException(String) - Constructor for exception org.mule.example.errorhandler.exceptions.BusinessException
 
BusinessException(String, Throwable) - Constructor for exception org.mule.example.errorhandler.exceptions.BusinessException
 
BusinessHandler - Class in org.mule.example.errorhandler.handlers
BusinessHandler
BusinessHandler() - Constructor for class org.mule.example.errorhandler.handlers.BusinessHandler
 
businessHandlerMessage() - Static method in class org.mule.example.errorhandler.LocaleMessage
 
BYTE_ARRAY - Static variable in class org.mule.expression.MessagePayloadExpressionEvaluator
 
BYTE_ARRAY - Static variable in class org.mule.transformer.types.DataTypeFactory
 
BYTE_ARRAY_DATA_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
ByteArrayToHexString - Class in org.mule.transformer.simple
Converts a Byte array to a Hex String.
ByteArrayToHexString() - Constructor for class org.mule.transformer.simple.ByteArrayToHexString
 
ByteArrayToMuleMessage - Class in org.mule.transformer.simple
TODO
ByteArrayToMuleMessage() - Constructor for class org.mule.transformer.simple.ByteArrayToMuleMessage
 
ByteArrayToObject - Class in org.mule.transformer.simple
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.
ByteArrayToObject() - Constructor for class org.mule.transformer.simple.ByteArrayToObject
 
ByteArrayToSerializable - Class in org.mule.transformer.simple
ByteArrayToSerializable converts a serialized object to its object representation
ByteArrayToSerializable() - Constructor for class org.mule.transformer.simple.ByteArrayToSerializable
 
ByteOrMessageProtocolDefinitionParser - Class in org.mule.transport.tcp.config
 
ByteOrMessageProtocolDefinitionParser(Class, Class) - Constructor for class org.mule.transport.tcp.config.ByteOrMessageProtocolDefinitionParser
 

C

cache - Variable in class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector
 
cache - Variable in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
cache - Variable in class org.mule.transport.jms.jndi.CachedJndiNameResolver
 
CACHE_JMS_SESSIONS_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
CacheControlHeader - Class in org.mule.transport.http
Includes basic configuration for the HTTP Cache-Control Header
CacheControlHeader() - Constructor for class org.mule.transport.http.CacheControlHeader
 
CachedHttpServletRequest - Class in org.mule.transport.servlet
 
CachedHttpServletRequest(HttpServletRequest) - Constructor for class org.mule.transport.servlet.CachedHttpServletRequest
 
CachedJndiNameResolver - Class in org.mule.transport.jms.jndi
Defines a JndiNameResolver that uses a cache in order to store the already resolved names.
CachedJndiNameResolver() - Constructor for class org.mule.transport.jms.jndi.CachedJndiNameResolver
 
CachedResource - Class in org.mule.config.spring.util
Spring 2.x is picky about open/closed input streams, as it requires a closed stream (fully read resource) to enable automatic validation detection (DTD or XSD).
CachedResource(byte[]) - Constructor for class org.mule.config.spring.util.CachedResource
 
CachedResource(String, String) - Constructor for class org.mule.config.spring.util.CachedResource
 
CachedResource(byte[], String) - Constructor for class org.mule.config.spring.util.CachedResource
 
CachedResource(Reader, String) - Constructor for class org.mule.config.spring.util.CachedResource
 
cacheMessages - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
CachingStrategy - Interface in org.mule.api.cache
Defines a way to process a MuleEvent using a cache.
cachingStrategy(CachingStrategy) - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
call(Object[], ExpressionLanguageContext) - Method in interface org.mule.api.el.ExpressionLanguageFunction
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
Callable - Interface in org.mule.api.lifecycle
Callable is used to provide a Service with an interface that supports event calls.
CallableEntryPointResolver - Class in org.mule.model.resolvers
An entry-point resolver that only allows Service objects that implement the Callable interface
CallableEntryPointResolver() - Constructor for class org.mule.model.resolvers.CallableEntryPointResolver
 
callableMethod - Static variable in class org.mule.model.resolvers.CallableEntryPointResolver
 
CallableSqlStatementStrategy - Class in org.mule.transport.jdbc.sqlstrategy
Implements strategy for executing simple stored procedures.
CallableSqlStatementStrategy() - Constructor for class org.mule.transport.jdbc.sqlstrategy.CallableSqlStatementStrategy
 
callableSQLStrategy - Variable in class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
CallAnnotationParser - Class in org.mule.module.ibeans.config
The parser responsible for parsing Call annotations.
CallAnnotationParser() - Constructor for class org.mule.module.ibeans.config.CallAnnotationParser
 
CallbackOutputStream - Class in org.mule.model.streaming
 
CallbackOutputStream(OutputStream, CallbackOutputStream.Callback) - Constructor for class org.mule.model.streaming.CallbackOutputStream
 
CallbackOutputStream.Callback - Interface in org.mule.model.streaming
 
callbacks - Variable in class org.mule.lifecycle.RegistryLifecycleManager
 
CallInterfaceBinding - Class in org.mule.module.ibeans.config
An instance of a binding that matches iBean method name with an endpoint to invoke.
CallInterfaceBinding(FlowConstruct) - Constructor for class org.mule.module.ibeans.config.CallInterfaceBinding
 
CallOutboundEndpoint - Class in org.mule.module.ibeans.spi.support
A dynamic outbound endpoint defined when using the Call annotation.
CallOutboundEndpoint(MuleContext, AnnotatedEndpointData) - Constructor for class org.mule.module.ibeans.spi.support.CallOutboundEndpoint
 
CallRequestEndpoint - Class in org.mule.module.ibeans.spi.support
A dynamic inbound endpoint used for request calls defined using the Call annotation.
CallRequestEndpoint(MuleContext, AnnotatedEndpointData) - Constructor for class org.mule.module.ibeans.spi.support.CallRequestEndpoint
 
canClose(Class<?>) - Method in interface org.mule.api.util.StreamCloser
 
canClose(Class) - Method in class org.mule.module.xml.util.XMLStreamCloser
 
canHostFullWars() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
canHostFullWars() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
A helper method to differentiate between jetty-based connectors which can host full wars and ones which can't.
cannotAllocateManagedInstance() - Static method in class org.mule.module.jca.i18n.JcaMessages
 
cannotBindToAddress(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
cannotCopyStreamPayload(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotFindBindingForMethod(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotInstanciateFinder(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotInvokeCallWithoutOperation() - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
cannotLoadFromClasspath(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotLocateOrCreateServer() - Static method in class org.mule.module.management.i18n.ManagementMessages
 
cannotPauseResumeJcaComponent() - Static method in class org.mule.module.jca.i18n.JcaMessages
 
cannotReadPayloadAsBytes(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotReadPayloadAsString(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotRenameInboundScopeProperty(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotSetObjectOnceItHasBeenSet(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotSetPropertyOnObjectWithParamType(String, Class<?>, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotStartTransaction(String) - Static method in class org.mule.config.i18n.CoreMessages
 
cannotUseTxAndRemoteSync() - Static method in class org.mule.config.i18n.CoreMessages
 
canOnlySetFileOrXQuery() - Static method in class org.mule.module.xml.i18n.XmlMessages
 
canOnlySetFileOrXslt() - Static method in class org.mule.module.xml.i18n.XmlMessages
 
canTakeFromStore() - Method in class org.mule.util.queue.QueueInfo
 
capacity - Variable in class org.mule.util.queue.DefaultQueueInfoDelegate
 
capacity - Variable in class org.mule.util.queue.QueueConfiguration
 
captureMemorySnapshot() - Method in class org.mule.module.management.mbean.YourKitProfilerService
This method is just a convenient replacement of captureSnapshot(YourKitProfilerServiceMBean.SNAPSHOT_WITH_HEAP)
captureMemorySnapshot() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
This method is just a convenient replacement of captureSnapshot(YourKitProfilerServiceMBean.SNAPSHOT_WITH_HEAP)
captureReplyToDestination() - Method in interface org.mule.api.MuleEvent
Set the reply-to destination from the current message, and remove it from the message, to prevent any further propagation.
captureReplyToDestination() - Method in class org.mule.DefaultMuleEvent
 
captureReplyToDestination() - Method in class org.mule.VoidMuleEvent
 
captureSnapshot(long) - Method in class org.mule.module.management.mbean.YourKitProfilerService
Captures snapshot: write profiling information to file.
captureSnapshot(long) - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Captures snapshot: write profiling information to file.
CaseInsensitiveHashMap - Class in org.mule.util
A case-insensitive Map.
CaseInsensitiveHashMap() - Constructor for class org.mule.util.CaseInsensitiveHashMap
Constructs a new empty map with default size and load factor.
CaseInsensitiveHashMap(int) - Constructor for class org.mule.util.CaseInsensitiveHashMap
Constructs a new, empty map with the specified initial capacity.
CaseInsensitiveHashMap(int, float) - Constructor for class org.mule.util.CaseInsensitiveHashMap
Constructs a new, empty map with the specified initial capacity and load factor.
CaseInsensitiveHashMap(Map) - Constructor for class org.mule.util.CaseInsensitiveHashMap
Constructor copying elements from another map.
CatalogAdminService - Interface in org.mule.example.bookstore
Administration interface for adding new books to the bookstore's catalog
CatalogService - Interface in org.mule.example.bookstore
Interface for working with the bookstore's catalog of books
CatalogServiceImpl - Class in org.mule.example.bookstore
Bookstore catalog service which implements both the public interface for browsing the catalog and the admin interface for adding books to the catalog.
CatalogServiceImpl() - Constructor for class org.mule.example.bookstore.CatalogServiceImpl
 
catchAll(MuleEvent) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
 
catchAllStrategy - Variable in class org.mule.service.ServiceCompositeMessageSource
 
CatchMessagingExceptionStrategy - Class in org.mule.exception
 
CatchMessagingExceptionStrategy() - Constructor for class org.mule.exception.CatchMessagingExceptionStrategy
 
category - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
causedBy(Class) - Method in exception org.mule.api.MessagingException
Evaluates if the exception was caused (instance of) by the provided exception type
causedExactlyBy(Class) - Method in exception org.mule.api.MessagingException
Evaluates if the exception was caused by the type and only the type provided exception type i,e: if cause exception is NullPointerException will only return true if provided exception type is NullPointerException
causedRollback() - Method in exception org.mule.api.MessagingException
Signals if the exception cause rollback of any current transaction if any or if the message source should rollback incoming message
causeMatches(String) - Method in exception org.mule.api.MessagingException
Checks the cause exception type name matches the provided regex.
CC_ADDRESSES_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
chain(MessageProcessor...) - Method in interface org.mule.api.processor.MessageProcessorChainBuilder
 
chain(MessageProcessorBuilder...) - Method in interface org.mule.api.processor.MessageProcessorChainBuilder
 
chain(MessageProcessor...) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
chain(List<MessageProcessor>) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
chain(MessageProcessorBuilder...) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
chainBefore(MessageProcessor) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
chainBefore(MessageProcessorBuilder) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
ChainedReader - Class in org.mule.util
ChainedReader allows Reader objects to be chained together.
ChainedReader(Reader, Reader) - Constructor for class org.mule.util.ChainedReader
 
ChainedThreadingProfile - Class in org.mule.config
This was written (perhaps too far in advance) with an eye to how we will manage default values in a dynamic environment.
ChainedThreadingProfile() - Constructor for class org.mule.config.ChainedThreadingProfile
Generate a mutable threading profile with fixed default values taken from ThreadingProfile.DEFAULT_THREADING_PROFILE
ChainedThreadingProfile(ThreadingProfile) - Constructor for class org.mule.config.ChainedThreadingProfile
Generate a mutable threading profile with dynamic default values taken from the given delegate.
ChainedThreadingProfile(ThreadingProfile, boolean) - Constructor for class org.mule.config.ChainedThreadingProfile
Generate a mutable threading profile.
ChainingRouter - Class in org.mule.routing.outbound
ChainingRouter is used to pass a Mule event through multiple targets using the result of the first as the input for the second.
ChainingRouter() - Constructor for class org.mule.routing.outbound.ChainingRouter
 
changeWorkingDirectory(String) - Method in class org.mule.transport.sftp.SftpClient
 
Channel - Annotation Type in org.mule.api.annotations.meta
Marks an endpoint annotation and provides the connector protocol and type.
channel - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
CHANNEL_OVERRIDES - Static variable in class org.mule.config.endpoint.ConfigurableTransportFactory
 
CHANNEL_OVERRIDES_FILE - Static variable in class org.mule.config.endpoint.ConfigurableTransportFactory
 
CHANNEL_PROPERTY - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
 
CHANNEL_SFTP - Static variable in class org.mule.transport.sftp.SftpClient
 
ChannelType - Enum in org.mule.api.annotations.meta
Possible channel types in iBeans
CHARACTER_ENCODING_PROPERTY_KEY - Static variable in class org.mule.transport.servlet.ServletConnector
This property name is used to store the character encoding of the HttpServletRequest to the MuleMessage
CharSetUtils - Class in org.mule.util
 
CharSetUtils() - Constructor for class org.mule.util.CharSetUtils
 
chat(ChatString) - Method in class org.mule.example.hello.ChitChatter
 
ChatString - Class in org.mule.example.hello
ChatString TODO (document class)
ChatString() - Constructor for class org.mule.example.hello.ChatString
 
ChatStringToString - Class in org.mule.example.hello
NameStringToChatString is a dummy transformer used in the hello world application to transform the ChatString object into a string.
ChatStringToString() - Constructor for class org.mule.example.hello.ChatStringToString
 
checkAndConfigure() - Method in class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector.ConfigWatchDog
 
CheckDatabaseOrUrl - Class in org.mule.transport.jdbc.config
 
CheckDatabaseOrUrl() - Constructor for class org.mule.transport.jdbc.config.CheckDatabaseOrUrl
 
checkDisposed() - Method in class org.mule.registry.TransientRegistry
 
checkElementNameUnique(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
checkElementNameUnique(Element) - Method in class org.mule.config.spring.parsers.specific.FlowRefDefinitionParser
 
checkEtag - Variable in class org.mule.transport.http.PollingHttpMessageReceiver
 
CheckExclusiveAttribute - Class in org.mule.config.spring.parsers.processors
If this attribute is present, no other can be
CheckExclusiveAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.CheckExclusiveAttribute
 
CheckExclusiveAttribute.CheckExclusiveAttributeException - Exception in org.mule.config.spring.parsers.processors
 
CheckExclusiveAttributeAndText - Class in org.mule.config.spring.parsers.processors
If this attribute is present, no other can be
CheckExclusiveAttributeAndText(String) - Constructor for class org.mule.config.spring.parsers.processors.CheckExclusiveAttributeAndText
 
CheckExclusiveAttributeAndText.CheckExclusiveAttributeException - Exception in org.mule.config.spring.parsers.processors
 
CheckExclusiveAttributes - Class in org.mule.config.spring.parsers.processors
Attributes from two different sets cannot appear together
CheckExclusiveAttributes(String[][]) - Constructor for class org.mule.config.spring.parsers.processors.CheckExclusiveAttributes
 
CheckExclusiveAttributes.CheckExclusiveAttributesException - Exception in org.mule.config.spring.parsers.processors
 
CheckExclusiveAttributesAndChildren - Class in org.mule.config.spring.parsers.processors
Attributes and children elements cannot appear together.
CheckExclusiveAttributesAndChildren(String[], String[]) - Constructor for class org.mule.config.spring.parsers.processors.CheckExclusiveAttributesAndChildren
 
CheckExclusiveAttributesAndChildren.CheckExclusiveAttributesAndChildrenException - Exception in org.mule.config.spring.parsers.processors
 
CheckExclusiveAttributesAndChildren.CheckExclusiveAttributesAndChildrenException(String) - Constructor for exception org.mule.config.spring.parsers.processors.CheckExclusiveAttributesAndChildren.CheckExclusiveAttributesAndChildrenException
 
checkFile(File, String, boolean, boolean) - Method in class org.mule.tools.anttasks.FileChecker
Check that a specified file parameter is valid
checkFrozen() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
checkInboundExchangePattern() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
checkInvariants(Destination) - Method in class org.mule.transport.jms.DefaultJmsTopicResolver
Perform some sanity checks, will complain in the log.
checkKeyStore() - Method in class org.mule.transport.http.HttpsMessageReceiver
 
checkKeyStore() - Method in class org.mule.transport.ssl.SslMessageReceiver
 
checkKeyStoreContainsAlias(KeyStore) - Method in class org.mule.api.security.tls.TlsConfiguration
 
checkLifecycleForPropertySet(String, String) - Method in class org.mule.DefaultMuleContext
 
checkMustForceSync() - Method in class org.mule.transport.file.FileMessageReceiver
If we will be autodeleting File objects, events must be processed synchronously to avoid a race
checkPhase(String) - Method in interface org.mule.api.lifecycle.LifecycleManager
Will check that the phase passed in is a valid next phase for this lifecycle manager.
checkPhase(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
CheckRequiredAttributes - Class in org.mule.config.spring.parsers.processors
All attributes from at least one set must be provided
CheckRequiredAttributes(String[][]) - Constructor for class org.mule.config.spring.parsers.processors.CheckRequiredAttributes
 
CheckRequiredAttributes.CheckRequiredAttributesException - Exception in org.mule.config.spring.parsers.processors
 
CheckRequiredAttributesWhenNoChildren - Class in org.mule.config.spring.parsers.processors
All attributes from at least one set must be provided when there are no child elements with the name specified present.
CheckRequiredAttributesWhenNoChildren(String[][], String) - Constructor for class org.mule.config.spring.parsers.processors.CheckRequiredAttributesWhenNoChildren
 
checkReturnClass(Object, MuleEvent) - Method in class org.mule.transformer.AbstractMessageTransformer
Check if the return class is supported by this transformer
checkScopeForWriteAccess(PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
checkState() - Method in class org.mule.retry.async.FutureRetryContext
 
checkTransformer(String, Class<?>, String) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
checkTransformerReturnClass(Transformer, Object) - Static method in class org.mule.transformer.TransformerUtils
Checks whether a given value is a valid output for a transformer.
checkVersion(MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
ChildAddressDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint.support
Generate an Endpoint URI from simple address components.
ChildAddressDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.ChildAddressDefinitionParser
 
ChildAddressDefinitionParser(String, boolean) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.ChildAddressDefinitionParser
 
ChildDefinitionParser - Class in org.mule.config.spring.parsers.generic
Creates a definition parser that will construct a single child element and inject it into the parent object (the enclosing XML element).
ChildDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.ChildDefinitionParser
The class will be inferred from the class attribute
ChildDefinitionParser(String, Class<?>) - Constructor for class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
ChildDefinitionParser(String, Class<?>, boolean) - Constructor for class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
ChildDefinitionParser(String, Class<?>, Class<?>) - Constructor for class org.mule.config.spring.parsers.generic.ChildDefinitionParser
The class (which is inferred from the class attribute if null here) is checked to be a subclass of the constraint
ChildDefinitionParser(String, Class<?>, Class<?>, boolean) - Constructor for class org.mule.config.spring.parsers.generic.ChildDefinitionParser
The class (which is inferred from the class attribute if null here) is checked to be a subclass of the constraint.
ChildEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint.support
A parser for "embedded" endpoints - ie inbound, outbound and response endpoints.
ChildEndpointDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.ChildEndpointDefinitionParser
 
ChildListDefinitionParser - Class in org.mule.config.spring.parsers.collection
 
ChildListDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildListDefinitionParser
 
ChildListEntryDefinitionParser - Class in org.mule.config.spring.parsers.collection
Process an element as a value that is appended to a list in the parent object (the enclosing XML element).
ChildListEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser
Takes value from enclosed text
ChildListEntryDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser
Takes value from attribute
ChildListEntryDefinitionParser.ListEntry - Class in org.mule.config.spring.parsers.collection
 
ChildListEntryDefinitionParser.ListEntry() - Constructor for class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser.ListEntry
 
ChildListEntryDefinitionParser.ListEntry(Object) - Constructor for class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser.ListEntry
 
ChildMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single Map and processes standard Spring sub elements.
ChildMapDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildMapDefinitionParser
 
ChildMapEntryDefinitionParser - Class in org.mule.config.spring.parsers.collection
 
ChildMapEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser
 
ChildMapEntryDefinitionParser(String, String, String) - Constructor for class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser
 
ChildMapEntryDefinitionParser.KeyValuePair - Class in org.mule.config.spring.parsers.collection
 
ChildMapEntryDefinitionParser.KeyValuePair() - Constructor for class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
ChildMapEntryDefinitionParser.KeyValuePair(String, Object) - Constructor for class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
ChildPropertiesDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single Properties object and processes standard Spring sub elements.
ChildPropertiesDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildPropertiesDefinitionParser
 
ChildSingletonMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
 
ChildSingletonMapDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.ChildSingletonMapDefinitionParser
 
ChitChatter - Class in org.mule.example.hello
ChitChatter TODO (document class)
ChitChatter() - Constructor for class org.mule.example.hello.ChitChatter
 
chmod(String, int) - Method in class org.mule.transport.sftp.SftpClient
 
ChoiceDefinition - Class in org.mule.config.dsl.routers
TODO
ChoiceDefinition() - Constructor for class org.mule.config.dsl.routers.ChoiceDefinition
 
ChoiceMessagingExceptionStrategy - Class in org.mule.exception
Selects which exception strategy to execute based on filtering.
ChoiceMessagingExceptionStrategy() - Constructor for class org.mule.exception.ChoiceMessagingExceptionStrategy
 
ChoiceRouter - Class in org.mule.routing
Routes the event to a singleMessageProcessor using a Filter to evaluate the event being processed and find the first route that can be used.
ChoiceRouter() - Constructor for class org.mule.routing.ChoiceRouter
 
ChoiceRouterFactoryBean - Class in org.mule.config.spring.factories
 
ChoiceRouterFactoryBean() - Constructor for class org.mule.config.spring.factories.ChoiceRouterFactoryBean
 
CityStroller - Class in org.mule.example.gpswalker
Generates a random walk around a city
CityStroller() - Constructor for class org.mule.example.gpswalker.CityStroller
 
CLASS_PROPERTY - Static variable in class org.mule.transformer.simple.MapToBean
"className"
classLoader - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
 
classLoader - Variable in class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
ClassloaderSwitchingMBeanWrapper - Class in org.mule.module.management.agent
Ensures any external jmx invocation (like e.g.
ClassloaderSwitchingMBeanWrapper(T, Class<T>, ClassLoader) - Constructor for class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
CLASSNAME_ADAPTER - Static variable in class org.mule.module.management.agent.JdmkAgent
A FQN of the adaptor class to instantiate via reflection.
CLASSNAME_ANNOTATIONS_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
If the annotations module is on the classpath, also enable annotations config builder
CLASSNAME_DEFAULT_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
Don't use a class object so the core doesn't depend on mule-module-spring-config.
CLASSNAME_DEFAULT_IDLE_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
This builder sets up the configuration for an idle Mule node - a node that doesn't do anything initially but is fed configuration during runtime
CLASSNAME_IBEANS_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
If the iBeans module is on the classpath, this config builder can be used to scan for iBeans annotations.
CLASSNAME_MULE_CONTAINER - Static variable in class org.mule.module.reboot.MuleContainerWrapper
 
CLASSNAME_SPRING_CONFIG_BUILDER - Static variable in class org.mule.module.launcher.descriptor.ApplicationDescriptor
Required to support the '-config spring' shortcut.
CLASSNAME_SPRING_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
Required to support the '-config spring' shortcut.
ClassOrRefDefinitionParser - Class in org.mule.config.spring.parsers
 
ClassOrRefDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.ClassOrRefDefinitionParser
 
CLASSPATH_EMPTY - Static variable in class org.mule.module.launcher.MuleApplicationClassLoader
 
ClasspathScanner - Class in org.mule.util.scan
This class can be used to scan the classpath for classtypes (or interfaces they implement) or for annotations on the classpath.
ClasspathScanner(String...) - Constructor for class org.mule.util.scan.ClasspathScanner
 
ClasspathScanner(ClassLoader, String...) - Constructor for class org.mule.util.scan.ClasspathScanner
 
ClassReader - Class in org.mule.config.spring.util
This is the class file reader for obtaining the parameter names for declared methods in a class.
ClassReader(byte[], Map<String, Method>) - Constructor for class org.mule.config.spring.util.ClassReader
 
ClassScanner - Interface in org.mule.util.scan
This interface is used by scanners to let the ClasspathScanner know if there was a match on the class and whan the class was.
ClassUtils - Class in org.mule.util
Extend the Apache Commons ClassUtils to provide additional functionality.
ClassUtils() - Constructor for class org.mule.util.ClassUtils
 
clazz - Variable in class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
cleanAndAdd(MuleEventContext) - Static method in class org.mule.transport.soap.axis.extras.AxisCleanAndAddProperties
 
cleanup() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
cleanup() - Method in class org.mule.module.jca.MuleManagedConnection
Initiates a cleanup of the client-specific state maintained by a ManagedConnection instance.
cleanupDerbyDb(String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
cleanupDerbyDb(String, String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
cleanUpPayload(Object) - Method in class org.mule.module.cxf.support.OutputPayloadInterceptor
 
cleanupTempDir(SftpClient, String, String) - Method in class org.mule.transport.sftp.SftpUtil
 
clear() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
clear() - Method in class org.mule.el.context.InboundAttachmentMapContext
 
clear() - Method in class org.mule.el.context.MessagePropertyMapContext
 
clear() - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
clear() - Method in class org.mule.expression.InboundAttachmentsMap
 
clear() - Method in class org.mule.expression.OutboundAttachmentsMap
 
clear() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
clear() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
clear() - Method in class org.mule.management.stats.AllStatistics
 
clear() - Method in class org.mule.management.stats.ComponentStatistics
 
clear() - Method in class org.mule.management.stats.FlowConstructStatistics
 
clear() - Method in class org.mule.management.stats.RouterStatistics
 
clear() - Method in class org.mule.management.stats.SedaServiceStatistics
 
clear() - Method in class org.mule.management.stats.ServiceStatistics
 
clear() - Method in class org.mule.module.launcher.util.ObservableList
 
clear() - Method in class org.mule.module.management.mbean.StatisticsService
 
clear() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
clear() - Static method in class org.mule.RequestContext
Deprecated. Resets the current request context (clears all information).
clear() - Method in class org.mule.routing.EventGroup
Removes all events from this group.
clear() - Method in class org.mule.transaction.TransactionCoordination
 
clear() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Clears the pool, removing all pooled instances.
clear() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
clear(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
clear() - Method in class org.mule.transport.http.multipart.MultiMap
 
clear() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.mule.util.ExceptionHolder
 
clear() - Method in class org.mule.util.MapCombiner
 
clear() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
clear() - Method in interface org.mule.util.pool.ObjectPool
 
clearDispatchers() - Method in class org.mule.transport.AbstractConnector
 
CLEARED - Static variable in class org.mule.module.launcher.util.ElementEvent
 
clearEnrichers() - Method in interface org.mule.api.expression.ExpressionManager
Clears all registered enrichers from the manager.
clearEnrichers() - Method in class org.mule.expression.DefaultExpressionManager
 
clearEvaluators() - Method in interface org.mule.api.expression.ExpressionManager
Clears all registered evaluators from the manager.
clearEvaluators() - Method in class org.mule.expression.DefaultExpressionManager
Clears all registered evaluators from the manager.
clearFlowAssertions() - Method in class org.mule.tck.junit4.FunctionalTestCase
 
clearFlowVariables() - Method in interface org.mule.api.MuleEvent
 
clearFlowVariables() - Method in class org.mule.DefaultMuleEvent
 
clearFlowVariables() - Method in class org.mule.VoidMuleEvent
 
clearProperties() - Method in interface org.mule.api.MuleMessage
Deprecated. use MuleMessage.clearProperties(org.mule.api.transport.PropertyScope) instead
clearProperties(PropertyScope) - Method in interface org.mule.api.MuleMessage
Removes all properties on this message in the given scope.
clearProperties() - Method in interface org.mule.api.MuleSession
 
clearProperties() - Method in class org.mule.DefaultMuleMessage
Removes all properties on this message in the PropertyScope.INVOCATION and PropertyScope.OUTBOUND.
clearProperties(PropertyScope) - Method in class org.mule.DefaultMuleMessage
Removes all properties on this message in the given scope.
clearProperties() - Method in class org.mule.message.ExceptionMessage
Removes all properties on this message
clearProperties() - Method in class org.mule.MessagePropertiesContext
Removes all properties from all scopes except for SESSION and INBOUND (which is read-only).
clearProperties(PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
clearProperties() - Method in class org.mule.session.DefaultMuleSession
 
clearRequesters() - Method in class org.mule.transport.AbstractConnector
 
clearSessionVariables() - Method in interface org.mule.api.MuleEvent
 
clearSessionVariables() - Method in class org.mule.DefaultMuleEvent
 
clearSessionVariables() - Method in class org.mule.VoidMuleEvent
 
clearStatistics() - Method in class org.mule.module.management.mbean.FlowConstructService
 
clearStatistics() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
clearStatistics() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
clearStatistics() - Method in class org.mule.module.management.mbean.ServiceService
 
clearStoreCache() - Method in class org.mule.util.store.MuleObjectStoreManager
 
clearWarnings() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
CLI_OPTIONS - Static variable in class org.mule.example.loanbroker.esn.LoanBrokerApp
 
CLI_OPTIONS - Static variable in class org.mule.module.boot.MuleBootstrap
 
CLI_OPTIONS - Static variable in class org.mule.module.launcher.MuleContainer
 
CLI_OPTIONS - Static variable in class org.mule.module.reboot.MuleContainerBootstrap
 
CLI_OPTIONS - Static variable in class org.mule.MuleServer
 
client - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
client - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
client - Variable in class org.mule.transport.http.HttpClientMessageRequester
 
CLIENT - Static variable in class org.mule.transport.tcp.TcpConnector
 
clientClass - Variable in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
clientConfig - Variable in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
clientConfig - Variable in class org.mule.transport.soap.axis.AxisMessageRequester
 
clientConnectionManager - Variable in class org.mule.transport.http.HttpConnector
 
ClientKeyStoreDefinitionParser - Class in org.mule.config.spring.parsers.specific.tls
 
ClientKeyStoreDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.tls.ClientKeyStoreDefinitionParser
 
ClientMessages - Class in org.mule.module.client.i18n
 
ClientMessages() - Constructor for class org.mule.module.client.i18n.ClientMessages
 
ClientNamespaceHandler - Class in org.mule.module.client.config
TODO
ClientNamespaceHandler() - Constructor for class org.mule.module.client.config.ClientNamespaceHandler
 
clientProviderAndClientConfigConfigured() - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
clientProxy - Variable in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
clone() - Method in interface org.mule.api.endpoint.EndpointBuilder
 
clone() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
clone() - Method in class org.mule.module.jca.MuleConnectionRequestInfo
 
clone() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
clone() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
clone() - Method in class org.mule.transaction.constraints.BatchConstraint
 
clone() - Method in class org.mule.transaction.constraints.ConstraintFilter
 
clone() - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
clone() - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
clone() - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
clone() - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
clone() - Method in class org.mule.transformer.simple.CopyAttachmentsTransformer
 
clone() - Method in class org.mule.transformer.simple.CopyPropertiesTransformer
 
clone() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
clone() - Method in class org.mule.transformer.simple.RemoveAttachmentTransformer
 
clone() - Method in class org.mule.transport.http.MuleHostConfiguration
 
clone(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
clone() - Method in class org.mule.util.CaseInsensitiveHashMap
Clones the map without cloning the keys or values.
cloneDataType() - Method in interface org.mule.api.transformer.DataType
Create an exact copy of this datatype
cloneDataType() - Method in class org.mule.transformer.types.SimpleDataType
 
cloneEventForRoutinng(MuleEvent, MessageProcessor) - Method in class org.mule.routing.FirstSuccessful
 
cloneMessage(MuleMessage) - Static method in class org.mule.api.context.notification.ServerNotification
 
cloneMessage(MuleMessage) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Create a fresh copy of a message.
ClosableClassReader - Class in org.mule.util.scan.annotations
A Class reader trhat will close the stream once initialised
ClosableClassReader(String) - Constructor for class org.mule.util.scan.annotations.ClosableClassReader
 
ClosableClassReader(InputStream) - Constructor for class org.mule.util.scan.annotations.ClosableClassReader
 
close(Object) - Method in class org.guiceyfruit.mule.support.DisposableCloser
 
close() - Method in class org.hibernate.connection.SimpleConnectionProvider
 
close() - Method in interface org.mule.api.store.ListableObjectStore
Close the underlying store.
close(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
close(Object) - Method in interface org.mule.api.util.StreamCloser
 
close() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
close() - Method in class org.mule.jndi.SimpleContext
 
close() - Method in class org.mule.model.streaming.CallbackOutputStream
 
close() - Method in class org.mule.model.streaming.DelegatingInputStream
 
close() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
close(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
close() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
close(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalDestination.ResponseConduit
 
close() - Method in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
close() - Method in class org.mule.module.jca.DefaultMuleConnection
Closes the connection.
close() - Method in interface org.mule.module.jca.MuleConnection
 
close() - Method in class org.mule.module.launcher.GoodCitizenClassLoader
A workaround for http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=5041014
close() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
close() - Method in class org.mule.module.pgp.LazyTransformedInputStream
 
close() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
close(Object) - Method in class org.mule.module.xml.util.XMLStreamCloser
 
close() - Method in class org.mule.tck.jndi.InMemoryContext
 
close() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
close() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
close() - Method in class org.mule.transport.http.HttpServerConnection
 
close() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
close() - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
End the current part.
close() - Method in class org.mule.transport.http.ReleasingInputStream
 
close() - Method in class org.mule.transport.http.ResponseWriter
 
close(Connection) - Static method in class org.mule.transport.jdbc.JdbcUtils
 
close() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
close(MessageProducer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageProducer
close(MessageConsumer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageConsumer
close(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes the MuleSession
close(TemporaryQueue) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryQueue
close(TemporaryTopic) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryTopic
close() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
close() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
close() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
close() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
close() - Method in class org.mule.transport.sftp.SftpInputStream
 
close() - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
close() - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
close() - Method in class org.mule.util.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.mule.util.ChainedReader
 
close() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
close() - Method in interface org.mule.util.pool.ObjectPool
 
close() - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
close() - Method in class org.mule.util.store.ManagedObjectStore
 
close() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
close() - Method in class org.mule.util.store.ObjectStorePartition
 
close(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
close() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
close(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
close() - Method in class org.mule.util.store.QueuePersistenceObjectStore
 
close() - Method in class org.mule.util.store.QueueStoreAdapter
 
close() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
CLOSE_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
closeConnection(Connection) - Method in class org.hibernate.connection.SimpleConnectionProvider
 
closeConsumer() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.  
closeConsumer() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
closeQuietly(MessageProducer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageProducer without throwing an exception (an error message is logged instead).
closeQuietly(MessageConsumer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageConsumer without throwing an exception (an error message is logged instead).
closeQuietly(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes the MuleSession without throwing an exception (an error message is logged instead).
closeQuietly(TemporaryQueue) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryQueue without throwing an exception (an error message is logged instead).
closeQuietly(TemporaryTopic) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryTopic without throwing an exception (an error message is logged instead).
closeQuietly(Channel) - Static method in class org.mule.util.FileUtils
Unconditionally close a Channel.
closeResource(boolean) - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
Close Sesison and consumer
closeResources() - Method in class org.mule.transaction.XaTransaction
 
closeSessionIfNoTransactionActive(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes a session if there is no active transaction in the current thread, otherwise the session will continue active until there is a direct call to close it.
closeStream(Object) - Method in interface org.mule.api.util.StreamCloserService
 
closeStream(MuleMessage) - Method in class org.mule.exception.AbstractExceptionListener
 
closeStream(Object) - Method in class org.mule.util.DefaultStreamCloserService
 
CLUSTER_NODE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
ClusterizableMessageSource - Interface in org.mule.api.source
Defines a message source that runs in only one node of a cluster.
ClusterizableMessageSourceWrapper - Class in org.mule.source
Wraps a ClusterizableMessageSource in order to manage the lifecycle of the wrapped instance differently depending if the node is primary or not inside a cluster.
ClusterizableMessageSourceWrapper(ClusterizableMessageSource) - Constructor for class org.mule.source.ClusterizableMessageSourceWrapper
 
ClusterizableMessageSourceWrapper(MuleContext, ClusterizableMessageSource, FlowConstruct) - Constructor for class org.mule.source.ClusterizableMessageSourceWrapper
 
ClusterNodeNotification - Class in org.mule.context.notification
Notifies when there are a cluster node event
ClusterNodeNotification(Object, int) - Constructor for class org.mule.context.notification.ClusterNodeNotification
 
ClusterNodeNotificationListener<T extends ClusterNodeNotification> - Interface in org.mule.api.context.notification
Defines a listener for ClusterNodeNotification
collectAllKeys(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
collectAllKeys() - Method in class org.mule.util.store.QueuePersistenceObjectStore
 
CollectionCorrelatorCallback - Class in org.mule.routing.correlation
A Correlator that correlates messages based on Mule correlation settings
CollectionCorrelatorCallback(MuleContext, boolean, String) - Constructor for class org.mule.routing.correlation.CollectionCorrelatorCallback
 
CollectionDataType<T> - Class in org.mule.transformer.types
A data type that represents a generified collection.
CollectionDataType(Class<? extends Collection>) - Constructor for class org.mule.transformer.types.CollectionDataType
Creates an untyped collection data type
CollectionDataType(Class<? extends Collection>, String) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionDataType(Class<? extends Collection>, Class, String) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionDataType(Class<? extends Collection>, Class) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionMessageSequence<T> - Class in org.mule.routing.outbound
A MessageSequence that retrieves elements from a Collection.
CollectionMessageSequence(Collection<T>) - Constructor for class org.mule.routing.outbound.CollectionMessageSequence
 
CollectionSplitter - Class in org.mule.routing
Splits a message that has a Collection, Iterable, MessageSequence or Iterator payload invoking the next message processor one for each item in it.
CollectionSplitter() - Constructor for class org.mule.routing.CollectionSplitter
 
CollectionUtils - Class in org.mule.util
 
CollectionUtils() - Constructor for class org.mule.util.CollectionUtils
 
ColumnAliasRowProcessor - Class in org.mule.transport.jdbc
Processes a row from a ResultSet using the column labels instead of the column names.
ColumnAliasRowProcessor() - Constructor for class org.mule.transport.jdbc.ColumnAliasRowProcessor
 
com.javaforge.bobber.archetype.model - package com.javaforge.bobber.archetype.model
 
com.javaforge.bobber.archetype.model.io.xpp3 - package com.javaforge.bobber.archetype.model.io.xpp3
 
com.javaforge.bobber.plugin.archetype - package com.javaforge.bobber.plugin.archetype
 
CombineCollectionsTransformer - Class in org.mule.transformer.simple
Takes a payload which is a Collection of Collections and turns into a single List.
CombineCollectionsTransformer() - Constructor for class org.mule.transformer.simple.CombineCollectionsTransformer
 
COMETD_CLIENT - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
 
COMMA - Static variable in class org.mule.transformer.TransformerUtils
 
commit() - Method in interface org.mule.api.transaction.Transaction
Commit the transaction
commit() - Method in class org.mule.exception.AbstractExceptionListener
 
commit() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Commit if authentication succeeds, otherwise return false
commit() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
commit() - Method in class org.mule.transaction.AbstractTransaction
 
commit() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
commit(Xid, boolean) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
commit() - Method in interface org.mule.util.queue.QueueSession
 
commit() - Method in class org.mule.util.xa.DefaultXASession
 
commit(Xid, boolean) - Method in class org.mule.util.xa.DefaultXASession
 
commitAndClose(Connection) - Static method in class org.mule.transport.jdbc.JdbcUtils
 
commitCurrentTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
committed - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
commitTransaction(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
commitTxButNoResource(Transaction) - Static method in class org.mule.config.i18n.CoreMessages
 
commitTxFilter - Variable in class org.mule.exception.AbstractExceptionListener
 
CommonsPoolObjectPool - Class in org.mule.util.pool
CommonsPoolProxyPool is an implementation of ObjectPool that internally uses the commons-pool GenericObjectPool and uses a ObjectFactory for creating new pooled instances.
CommonsPoolObjectPool(ObjectFactory, PoolingProfile, MuleContext) - Constructor for class org.mule.util.pool.CommonsPoolObjectPool
Creates a new pool and an Object factory with the ServiceDescriptor
Company - Class in org.mule.example.cep
A POJO for a company
Company(String, String) - Constructor for class org.mule.example.cep.Company
 
Company(String, String, double, double) - Constructor for class org.mule.example.cep.Company
 
CompanyRegistry - Class in org.mule.example.cep
A helper class to load and return the list of companies
CompanyRegistry() - Constructor for class org.mule.example.cep.CompanyRegistry
 
COMPARATOR_CLASS_NAME_PROPERTY - Static variable in class org.mule.transport.file.FileMessageReceiver
 
COMPARATOR_REVERSE_ORDER_PROPERTY - Static variable in class org.mule.transport.file.FileMessageReceiver
 
compare(PropertyScope, PropertyScope) - Method in class org.mule.api.transport.PropertyScope.ScopeComparator
 
compare(Preferred, Preferred) - Method in class org.mule.config.PreferredComparator
 
compare(MuleEvent, MuleEvent) - Method in class org.mule.routing.correlation.CorrelationSequenceComparator
 
compare(MuleEvent, MuleEvent) - Method in class org.mule.routing.EventGroup.ArrivalOrderEventComparator
 
compare(MuleMessage, MuleMessage) - Method in class org.mule.routing.EventGroup.ArrivalOrderMessageComparator
 
compare(String, String) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
compare(Object, Object) - Method in class org.mule.transport.file.comparator.OlderFirstComparator
 
compare(Class[], Class[], boolean) - Static method in class org.mule.util.ClassUtils
 
compare(Class[], Class[], boolean, boolean) - Static method in class org.mule.util.ClassUtils
Returns true if the types from array c2 are assignable to the types from c1 and the arrays are the same size.
compareAndSet(boolean, boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(Object) - Method in class org.mule.module.ibeans.config.IBeanHolder
 
compareTo(EventGroup) - Method in class org.mule.routing.EventGroup
Compare this EventGroup to another one.
compareTo(Object) - Method in class org.mule.transformer.TransformerWeighting
 
compareTo(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(WaitableBoolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(Object) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
COMPILED_EXPRESSION_MAX_CACHE_SIZE - Static variable in class org.mule.el.mvel.MVELExpressionExecutor
 
compiledExpressionsCache - Variable in class org.mule.el.mvel.MVELExpressionExecutor
 
compiledPatterns - Variable in class org.mule.transport.file.filters.FilenameRegexFilter
 
complement() - Method in class org.mule.util.concurrent.WaitableBoolean
 
completedPhases - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
completeTask(Task) - Method in class org.mule.module.jbpm.Jbpm
 
completeTask(Task, String, Map) - Method in class org.mule.module.jbpm.Jbpm
 
Component - Interface in org.mule.api.component
A Component component processes a MuleEvent by invoking the component instance that has been configured, optionally returning a result.
component - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
component - Variable in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Class<?>) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(ObjectFactory) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Callable) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Object) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Component) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component - Variable in class org.mule.context.notification.ComponentMessageNotification
 
component - Variable in class org.mule.service.AbstractService
 
COMPONENT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
COMPONENT_POST_INVOKE - Static variable in class org.mule.context.notification.ComponentMessageNotification
 
COMPONENT_PRE_INVOKE - Static variable in class org.mule.context.notification.ComponentMessageNotification
 
ComponentBuilder - Class in org.mule.config.dsl
TODO
ComponentBuilder.Scope - Enum in org.mule.config.dsl
 
componentCausedErrorIs(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ComponentDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ComponentDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ComponentDefinitionParser
 
ComponentDelegatingDefinitionParser - Class in org.mule.config.spring.parsers.specific
Allows for parsing either a shortcut component configuration by delegating to two different component parses depending on the existence of the class attribute.
ComponentDelegatingDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ComponentDelegatingDefinitionParser
 
ComponentException - Exception in org.mule.component
ComponentException should be thrown when some action on a component fails, such as starting or stopping
ComponentException(Message, MuleEvent, Component) - Constructor for exception org.mule.component.ComponentException
 
ComponentException(Message, MuleEvent, Component, Throwable) - Constructor for exception org.mule.component.ComponentException
 
ComponentException(MuleEvent, Component, Throwable) - Constructor for exception org.mule.component.ComponentException
 
ComponentLifecycleManager - Class in org.mule.component
The lifecycle manager responsible for managing lifecycle transitions for a Mule service.
ComponentLifecycleManager(String, Component) - Constructor for class org.mule.component.ComponentLifecycleManager
 
ComponentMessageNotification - Class in org.mule.context.notification
These notifications are fired when before and after a service component is invoked.
ComponentMessageNotification(MuleMessage, Component, FlowConstruct, int) - Constructor for class org.mule.context.notification.ComponentMessageNotification
 
ComponentMessageNotificationListener<T extends ComponentMessageNotification> - Interface in org.mule.api.context.notification
ComponentMessageNotificationListener is an observer interface that objects can use to receive notifications about messages being processed by components
ComponentMessageNotificationMixin - Interface in org.mule.example.notifications
 
ComponentNotFoundRuntimeException - Exception in org.mule.module.cxf.support
 
ComponentNotFoundRuntimeException(Message, Throwable) - Constructor for exception org.mule.module.cxf.support.ComponentNotFoundRuntimeException
 
ComponentNotFoundRuntimeException(Message) - Constructor for exception org.mule.module.cxf.support.ComponentNotFoundRuntimeException
 
componentNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
componentObject - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
ComponentStatistics - Class in org.mule.management.stats
 
ComponentStatistics() - Constructor for class org.mule.management.stats.ComponentStatistics
The constructor added to initialize the interval time in ms that stats are measured for from the property statIntervalTime.
composeName(Name, Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
composeName(String, String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
composeName(String, String) - Method in class org.mule.jndi.SimpleContext
 
composeName(Name, Name) - Method in class org.mule.jndi.SimpleContext
 
composeName(Name, Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
composeName(String, String) - Method in class org.mule.tck.jndi.InMemoryContext
 
CompositeConverter - Class in org.mule.transformer
Composes many converters to behave as a single one.
CompositeConverter(Converter...) - Constructor for class org.mule.transformer.CompositeConverter
Create a new conversion chain using the specified converters
CompositeConverterFilter - Class in org.mule.transformer.graph
 
CompositeConverterFilter(ConverterFilter...) - Constructor for class org.mule.transformer.graph.CompositeConverterFilter
 
CompositeDeploymentListener - Class in org.mule.module.launcher
 
CompositeDeploymentListener() - Constructor for class org.mule.module.launcher.CompositeDeploymentListener
 
CompositeMessageSource - Interface in org.mule.api.source
Composes multiple MessageSources.
CompositeMessageSourceFactoryBean - Class in org.mule.config.spring.factories
 
CompositeMessageSourceFactoryBean() - Constructor for class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
compressByteArray(byte[]) - Method in interface org.mule.util.compression.CompressionStrategy
 
compressByteArray(byte[]) - Method in class org.mule.util.compression.GZipCompression
Used for compressing a byte array into a new byte array using GZIP
COMPRESSION_DEFAULT - Static variable in interface org.mule.util.compression.CompressionStrategy
The fully qualified class name of the fallback CompressionStrategy implementation class to use, if no other can be found.
CompressionException - Exception in org.mule.util.compression
CompressionException TODO document
CompressionException(String) - Constructor for exception org.mule.util.compression.CompressionException
 
CompressionException(String, Throwable) - Constructor for exception org.mule.util.compression.CompressionException
 
CompressionHelper - Class in org.mule.util.compression
CompressionHelper a static class that provides facilities for compressing and uncompressing byte arrays
CompressionStrategy - Interface in org.mule.util.compression
CompressionStrategy is a base interface for Different compression strategies
compute() - Method in class org.mule.util.counters.impl.AggregateCounter
 
computeKey(ClassLoader) - Method in class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector.LoggerRepositoryCache
 
ConcurrentHashSet - Class in org.mule.util.concurrent
 
ConcurrentHashSet() - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int) - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int, float, int) - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
config - Variable in class org.mule.context.DefaultMuleContextBuilder
 
config - Variable in class org.mule.routing.ExpressionSplitter
 
config - Variable in class org.mule.routing.outbound.ExpressionMessageSplitter
 
ConfigChangeMonitorThreadFactory - Class in org.mule.module.launcher
A slightly tweaked default thread factory that uses the following pattern: [%s].config.change.%d.thread.%d, where %s stands for application name, the next number will tell one how many redeployments this app had during this container's lifetime and the last digit, thread count, should always be 1.
ConfigChangeMonitorThreadFactory(String) - Constructor for class org.mule.module.launcher.ConfigChangeMonitorThreadFactory
 
configNotFoundUsage() - Static method in class org.mule.config.i18n.CoreMessages
 
ConfigResource - Class in org.mule.config
A ConfigResource holds the url description (or location) and the url stream.
ConfigResource(String) - Constructor for class org.mule.config.ConfigResource
 
ConfigResource(URL) - Constructor for class org.mule.config.ConfigResource
 
ConfigResource(String, InputStream) - Constructor for class org.mule.config.ConfigResource
 
configResources - Variable in class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
configResources - Variable in class org.mule.tck.AbstractServiceAndFlowTestCase
 
ConfigurableJMXAuthenticator - Interface in org.mule.module.management.agent
 
ConfigurableKeyedObjectPool - Interface in org.mule.transport
A configurable KeyedObjectPool.
ConfigurableKeyedObjectPoolFactory - Interface in org.mule.transport
Simple factory for ConfigurableKeyedObjectPool instances.
ConfigurableTransportFactory - Class in org.mule.config.endpoint
TODO
ConfigurableTransportFactory(MuleContext) - Constructor for class org.mule.config.endpoint.ConfigurableTransportFactory
 
CONFIGURATION - Static variable in class org.mule.config.spring.parsers.specific.ConfigurationChildDefinitionParser
Name of the mule:configuration element
configuration - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configuration - Variable in class org.mule.module.xml.transformer.XQueryTransformer
 
CONFIGURATION_LOCATION - Static variable in class org.mule.module.cxf.CxfConfiguration
 
ConfigurationBuilder - Interface in org.mule.api.config
A ConfigurationBuilder is used to configure a Mule instance, represented by a MuleContext instance.
configurationBuilderError(ConfigurationBuilder) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderNoMatching(String) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderSuccess(ConfigurationBuilder, int) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderSuccess(ConfigurationBuilder, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ConfigurationChildDefinitionParser - Class in org.mule.config.spring.parsers.specific
Extend ChildDefinitionParser to include logic for identifying parent configuration element (since this only applies to "default" elements there's an ugliness here - contradicitions (non-default children of configuration) are avoided by the mule.xsd schema).
ConfigurationChildDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.ConfigurationChildDefinitionParser
 
ConfigurationDefinitionParser - Class in org.mule.config.spring.parsers.specific
Parses the element.
ConfigurationDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
ConfigurationException - Exception in org.mule.api.config
 
ConfigurationException(Message) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationException(Message, Throwable) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationPatternArchetypeMojo - Class in org.mule.tools.maven.archetype
Creates a new configuration pattern.
ConfigurationPatternArchetypeMojo() - Constructor for class org.mule.tools.maven.archetype.ConfigurationPatternArchetypeMojo
 
configure() - Method in class org.guiceyfruit.mule.MuleModule
 
configure(Properties) - Method in class org.hibernate.connection.SimpleConnectionProvider
 
configure(MuleContext) - Method in interface org.mule.api.config.ConfigurationBuilder
Will configure a MuleContext based on the configuration provided.
configure(MuleContext) - Method in class org.mule.config.builders.AbstractConfigurationBuilder
Will configure a MuleContext object based on the builders configuration settings.
configure(MuleContext) - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
Override to check for existence of configResouce before invocation, and set resources n configuration afterwards.
configure() - Method in class org.mule.module.guice.MuleSupportModule
 
configure(Map) - Method in interface org.mule.module.management.agent.ConfigurableJMXAuthenticator
 
configure(Map) - Method in class org.mule.module.management.support.SimplePasswordJmxAuthenticator
 
configure(ServerSocket, Boolean, InetSocketAddress, int) - Method in class org.mule.transport.tcp.TcpServerSocketFactory
 
configureBinding(JavaComponent, Object) - Static method in class org.mule.component.BindingUtils
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
configureComponentBindings() - Method in class org.mule.module.scripting.component.ScriptComponent
 
configureComponentMessageProcessor(MuleContext, MessageProcessorChainBuilder, Component) - Method in enum org.mule.construct.SimpleService.Type
 
configureContentLengthRemover(AbstractConfigurationPattern, MessageProcessorChainBuilder) - Static method in class org.mule.transport.http.construct.HttpProxy
 
configureContext(ExpressionLanguageContext) - Method in interface org.mule.api.el.ExpressionLanguageExtension
 
configureContext(ExpressionLanguageContext) - Method in class org.mule.module.xml.el.XMLExpressionLanguageExtension
 
configured - Variable in class org.mule.config.builders.AbstractConfigurationBuilder
 
configureDispatcherPool() - Method in class org.mule.transport.AbstractConnector
 
configureDispatcherPool() - Method in class org.mule.transport.file.FileConnector
 
configureEngine(AxisEngine) - Method in class org.mule.transport.soap.axis.extensions.MuleConfigProvider
Configure an AxisEngine.
configureFrom(URL, LoggerRepository) - Method in class org.mule.module.launcher.log4j.ApplicationAwareRepositorySelector
 
configureMessageProcessor(ServerFactoryBean, CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.LocalClientMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Bridge
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.SimpleService
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Validator
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.module.ws.construct.WSProxy
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.transport.http.construct.HttpProxy
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Bridge
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.SimpleService
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Validator
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.module.ws.construct.WSProxy
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.transport.http.construct.HttpProxy
 
configureMuleContext(MuleContext) - Method in class org.mule.module.guice.AbstractMuleGuiceModule
 
configureParserContext(ParserContext) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
configurePostProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configurePostProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configureProcessingStrategy(Element, BeanDefinitionBuilder, String) - Static method in class org.mule.config.spring.util.ProcessingStrategyUtils
 
configureProcessors(List<MessageProcessor>, ProcessingStrategy.StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in interface org.mule.api.processor.ProcessingStrategy
 
configureProcessors(List<MessageProcessor>, ProcessingStrategy.StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
configureProcessors(List<MessageProcessor>, ProcessingStrategy.StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.QueuedThreadPerProcessorProcessingStrategy
 
configureProcessors(List<MessageProcessor>, ProcessingStrategy.StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.SynchronousProcessingStrategy
 
configureProcessors(List<MessageProcessor>, ProcessingStrategy.StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.ThreadPerProcessorProcessingStrategy
 
configureQueue(MuleContext, String, QueueManager) - Method in class org.mule.config.QueueProfile
 
configureQueueManager(MuleContext) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
configureServer(Server) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
configureServer(Server) - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
configureSocket(boolean, Socket) - Method in class org.mule.transport.tcp.TcpConnector
 
configureStatistics() - Method in class org.mule.construct.AbstractFlowConstruct
 
configureStatistics() - Method in class org.mule.construct.Flow
 
configureSystemModel(MuleRegistry) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
configureThread(Thread) - Method in class org.mule.util.concurrent.NamedThreadFactory
 
configureThreadFactory(String, ThreadingProfile, ThreadPoolExecutor) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
configureThreadingProfiles(MuleRegistry) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
connect() - Method in interface org.mule.api.transport.Connectable
Make the connection to the underlying transport.
connect() - Method in class org.mule.module.management.mbean.EndpointService
 
connect() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
connect() - Method in class org.mule.transport.AbstractConnector
 
connect() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
connect() - Method in class org.mule.transport.soap.axis.transport.VoidURLConnection
 
connect() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
connect() - Method in interface org.mule.transport.xmpp.XmppConversation
Connect to the Jabber conversation, e.g.
Connectable - Interface in org.mule.api.transport
Interface for objects that should connect to a resource.
ConnectableLifecycleManager<O> - Class in org.mule.transport
TODO
ConnectableLifecycleManager(String, O) - Constructor for class org.mule.transport.ConnectableLifecycleManager
 
connected - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
ConnectException - Exception in org.mule.transport
When this exception is thrown it will trigger a retry (reconnection) policy to go into effect if one is configured.
ConnectException(Message, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
ConnectException(Message, Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
ConnectException(Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
connection - Variable in class org.mule.transport.xmpp.AbstractXmppConversation
 
CONNECTION_CONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
 
CONNECTION_DISCONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
 
CONNECTION_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
CONNECTION_FAILED - Static variable in class org.mule.context.notification.ConnectionNotification
 
connectionClosed(ConnectionEvent) - Method in class org.mule.module.jca.DefaultConnectionManager
 
connectionErrorOccurred(ConnectionEvent) - Method in class org.mule.module.jca.DefaultConnectionManager
 
ConnectionFactoryDefinitionParser - Class in org.mule.transport.jms.config
We want to set the connection factory as a pojo factory and then add attributes (username and password) on the parent
ConnectionFactoryDefinitionParser() - Constructor for class org.mule.transport.jms.config.ConnectionFactoryDefinitionParser
 
ConnectionFactoryWrapper - Class in org.mule.transport.jms.xa
 
ConnectionFactoryWrapper(Object) - Constructor for class org.mule.transport.jms.xa.ConnectionFactoryWrapper
 
ConnectionFactoryWrapper(Object, Boolean) - Constructor for class org.mule.transport.jms.xa.ConnectionFactoryWrapper
 
ConnectionInvocationHandler - Class in org.mule.transport.jms.xa
 
ConnectionInvocationHandler(Object) - Constructor for class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
ConnectionInvocationHandler(Object, Boolean) - Constructor for class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
ConnectionNotification - Class in org.mule.context.notification
Is fired by a connector when a connection is made or disconnected.
ConnectionNotification(Connectable, String, int) - Constructor for class org.mule.context.notification.ConnectionNotification
 
ConnectionNotificationListener<T extends ConnectionNotification> - Interface in org.mule.api.context.notification
ConnectionNotificationListener is an observer interface that objects can implement and then register themselves with the Mule manager to be notified when a Connection event occurs.
ConnectionWrapper - Class in org.mule.transport.jdbc.xa
Using for unification XAConnection and Connection
ConnectionWrapper(XAConnection) - Constructor for class org.mule.transport.jdbc.xa.ConnectionWrapper
 
ConnectNotifier - Class in org.mule.retry.notifiers
Fires a ConnectionNotification each time a retry attempt is made.
ConnectNotifier() - Constructor for class org.mule.retry.notifiers.ConnectNotifier
 
Connector - Interface in org.mule.api.transport
Connector is the mechanism used to connect to external systems and protocols in order to send and receive data.
connector - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
connector - Variable in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
connector - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
connector - Variable in class org.mule.transport.ajax.container.MuleAjaxServlet
 
connector - Variable in class org.mule.transport.DefaultReplyToHandler
 
connector - Variable in class org.mule.transport.ftp.FtpMessageDispatcher
 
connector - Variable in class org.mule.transport.ftp.FtpMessageReceiver
 
connector - Variable in class org.mule.transport.ftp.FtpMessageRequester
 
connector - Variable in class org.mule.transport.http.HttpClientMessageRequester
 
connector - Variable in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
connector - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
connector - Variable in class org.mule.transport.jms.Jms11Support
 
connector - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.  
connector - Variable in class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
 
connector - Variable in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
connector - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
connector - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
connector - Variable in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
connector - Variable in class org.mule.transport.rmi.RmiMessageReceiver
 
connector - Variable in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
connector - Variable in class org.mule.transport.servlet.MuleReceiverServlet
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageRequester
 
connector - Variable in class org.mule.transport.udp.UdpMessageDispatcher
 
connector - Variable in class org.mule.transport.udp.UdpMessageRequester
 
CONNECTOR_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
CONNECTOR_CLASS - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** Transport Service descriptor properties *****************************************************************************
CONNECTOR_DEFAULT_EXCHANGE_PATTERN - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_DISPATCHER_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_ENDPOINT_BUILDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_INBOUND_EXCHANGE_PATTERNS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_INBOUND_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_MESSAGE_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_META_ENDPOINT_BUILDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_NAME - Static variable in class org.mule.transport.servlet.MuleServletContextListener
 
CONNECTOR_OUTBOUND_EXCHANGE_PATTERNS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_OUTBOUND_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_PREFIX - Static variable in class org.mule.util.ObjectNameHelper
 
CONNECTOR_REQUESTER_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_RESPONSE_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SERVER - Static variable in class org.mule.module.management.config.JmxAgentDefinitionParser
 
CONNECTOR_SERVICE_ERROR - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SERVICE_FINDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SESSION_HANDLER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_TRANSACTED_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_TRANSACTION_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_XA_TRANSACTED_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
connectorCausedError() - Static method in class org.mule.config.i18n.CoreMessages
 
connectorCausedError(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
connectorDoesNotSupportSyncReceiveWhenTransacted() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
ConnectorException - Exception in org.mule.api.transport
ConnectorException Is thrown in the context of a Connector, usually some sort of transport level error where the connection has failed.
ConnectorException(Message, Connector) - Constructor for exception org.mule.api.transport.ConnectorException
 
ConnectorException(Message, Connector, Throwable) - Constructor for exception org.mule.api.transport.ConnectorException
 
ConnectorHolder<S extends Servlet,R extends MessageReceiver> - Interface in org.mule.transport.servlet.jetty
TODO
ConnectorLifecycleManager - Class in org.mule.transport
Manages the lifecycle of connectors in Mule.
ConnectorLifecycleManager(AbstractConnector) - Constructor for class org.mule.transport.ConnectorLifecycleManager
 
connectorName - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
connectorNotInJobDataMap() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
ConnectorPropertyEditor - Class in org.mule.config.spring.editors
Translates a connector name property into the corresponding Connector instance.
ConnectorPropertyEditor(MuleContext) - Constructor for class org.mule.config.spring.editors.ConnectorPropertyEditor
 
connectorSchemeIncompatibleWithEndpointScheme(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ConnectorService - Class in org.mule.module.management.mbean
 
ConnectorService(Connector) - Constructor for class org.mule.module.management.mbean.ConnectorService
 
ConnectorServiceMBean - Interface in org.mule.module.management.mbean
 
connectorWithProtocolNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
connectToJabberServer() - Method in class org.mule.transport.xmpp.XmppConnector
 
ConstraintFilter - Class in org.mule.transaction.constraints
 
ConstraintFilter() - Constructor for class org.mule.transaction.constraints.ConstraintFilter
 
ConstructorReference - Class in org.mule.config.spring.parsers.processors
 
ConstructorReference(String) - Constructor for class org.mule.config.spring.parsers.processors.ConstructorReference
 
ConsumableMuleMessageFilter - Class in org.mule.routing.filters
Filters messages that have a consumable payload.
ConsumableMuleMessageFilter() - Constructor for class org.mule.routing.filters.ConsumableMuleMessageFilter
 
consumer - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.  
consumer - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
consumer - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver.JmsThreadContext
 
ConsumerProducerInvocationHandler - Class in org.mule.transport.jms.xa
 
ConsumerProducerInvocationHandler(SessionInvocationHandler, Object) - Constructor for class org.mule.transport.jms.xa.ConsumerProducerInvocationHandler
 
consumers - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
containerAlreadyRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
containerManaged - Variable in class org.mule.module.jbpm.Jbpm
Indicates whether jBPM has been instantiated by Mule (false) or was passed in from somewhere else (true).
ContainerManagedLifecyclePhase - Class in org.mule.lifecycle.phases
A container-managed lifecycle phase is called by the container itself.
ContainerManagedLifecyclePhase(String, Class<?>, String) - Constructor for class org.mule.lifecycle.phases.ContainerManagedLifecyclePhase
 
containerMode - Variable in class org.mule.module.management.agent.JmxAgent
 
contains(String) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
contains(Serializable) - Method in interface org.mule.api.store.ObjectStore
Check whether the given Object is already registered with this store.
contains(Serializable, String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
contains(String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
contains(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
contains(Object, Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
contains(Serializable) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Check whether the given Object is already registered with this store.
contains(Object) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
contains(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersionRange
 
contains(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.InMemoryObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.ManagedObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
contains(Serializable) - Method in class org.mule.util.store.ObjectStorePartition
 
contains(Serializable, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
contains(Serializable, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.QueueStoreAdapter
 
containsAll(Collection<?>) - Method in class org.mule.module.launcher.util.ObservableList
 
containsHeader(String) - Method in class org.mule.transport.http.HttpRequest
 
containsHeader(String) - Method in class org.mule.transport.http.HttpResponse
 
containsHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
containsKey(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
containsKey(Object) - Method in class org.mule.el.context.InboundAttachmentMapContext
 
containsKey(Object) - Method in class org.mule.el.context.MessagePropertyMapContext
 
containsKey(Object) - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
containsKey(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
containsKey(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
containsKey(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
containsKey(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
containsKey(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
containsKey(Object) - Method in class org.mule.util.MapCombiner
 
ContainsTransformerMethods - Annotation Type in org.mule.api.annotations
Used to mark a that a class contains methods which are Mule Transformer.
containsType(Collection<?>, Class<?>) - Static method in class org.mule.util.CollectionUtils
 
containsType(Throwable, Class<?>) - Static method in class org.mule.util.ExceptionUtils
This method returns true if the throwable contains a Throwable that matches the specified class or subclass in the exception chain.
containsValue(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
containsValue(Object) - Method in class org.mule.el.context.AbstractMapContext
 
containsValue(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
containsValue(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
containsValue(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
containsValue(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
containsValue(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
containsValue(Object) - Method in class org.mule.util.MapCombiner
 
content - Variable in class org.mule.message.ds.StringDataSource
 
CONTENT_TYPE - Static variable in class org.mule.transport.email.transformers.PlainTextDataSource
 
CONTENT_TYPE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
CONTENT_TYPE_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
MuleEvent properties
CONTENT_TYPE_PROPERTY_KEY - Static variable in class org.mule.transport.servlet.ServletConnector
This property name is used to store the content type of the HttpServletRequest to the MuleMessage
CONTENT_TYPE_VALUE - Static variable in class org.mule.transport.http.components.RestServiceWrapper
 
ContentBasedRouter - Class in org.mule.config.dsl.routers
TODO
ContentBasedRouter() - Constructor for class org.mule.config.dsl.routers.ContentBasedRouter
 
contentType - Variable in class org.mule.message.ds.StringDataSource
 
contentTypeHeaderIsValid(Header) - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
context - Variable in class org.mule.config.bootstrap.SimpleRegistryBootstrap
 
context - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
 
context - Variable in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
context - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
context - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
 
context - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
 
CONTEXT_DISPOSED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_DISPOSING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
CONTEXT_INITIALISED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_INITIALISING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STARTED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STARTING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STOPPED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STOPPING - Static variable in class org.mule.context.notification.MuleContextNotification
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.config.builders.DeployableMuleXmlContextListener
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.transport.servlet.MuleServletContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.mule.config.builders.DeployableMuleXmlContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.mule.transport.servlet.MuleServletContextListener
 
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.AbstractSequenceRouter
Lets subclasses decide if the routing of a given message should continue or not after receiving a given response from a synchronous endpoint.
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.MulticastingRouter
Indicates that this router always routes messages to all the configured endpoints no matters what a given response is.
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.SequenceRouter
Determines if the routing should continue after receiving a given response from an synchronous endpoint.
ContinuousPollingReceiverWorker - Class in org.mule.transport
Bypass the regular scheduling mechanism in order to minimize latency and maximize throughput for transports which have low or no cost for performing a poll operation (such as an in-memory queue).
ContinuousPollingReceiverWorker(AbstractPollingMessageReceiver) - Constructor for class org.mule.transport.ContinuousPollingReceiverWorker
 
controlEvent(int) - Method in class org.mule.module.boot.MuleServerWrapper
Called whenever the native wrapper code traps a system control signal against the Java process.
controlEvent(int) - Method in class org.mule.module.boot.VersionWrapper
 
controlEvent(int) - Method in class org.mule.module.reboot.MuleContainerWrapper
Called whenever the native wrapper code traps a system control signal against the Java process.
Conventions - Class in org.mule.config.spring.parsers.assembly.configuration
Overloads the Spring Conventions class, specifically the Conventions.attributeNameToPropertyName(String) Method to evaluate the first character of the attribute name and ignore if it is upper case since this is not valid Bean notation and Mule uses upper case to signify a non-bean attribute name.
convert(String, MuleContext) - Method in interface org.mule.api.expression.PropertyConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.FilterConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.PropertiesConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.TransformerConverter
 
convert(String[]) - Static method in class org.mule.config.endpoint.AnnotatedEndpointData
 
convert(String) - Static method in class org.mule.config.spring.editors.QNamePropertyEditor
 
convert(Source, XMLOutputFactory) - Method in class org.mule.module.json.transformers.AbstractToFromXmlTransformer
Return result of transformation
Converter - Interface in org.mule.api.transformer
Defines a Transformer that is a data type converters, ie: convert data from a type to another without modifying the meaning of the data.
converterClassDoesNotImplementInterface(Class) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
ConverterFilter - Interface in org.mule.transformer.graph
Provides a way to filter a converters during the process of transformer resolution for a given source and result data types.
convertIBeansToMule(DataType) - Static method in class org.mule.module.ibeans.spi.support.DataTypeConverter
 
convertMuleToIBeans(DataType) - Static method in class org.mule.module.ibeans.spi.support.DataTypeConverter
 
convertMultiPartHeaders(Map<String, Object>) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
convertMultiPartHeaders(Map<String, Object>) - Method in class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
convertNumberToTargetClass(Number, Class<T>) - Static method in class org.mule.util.NumberUtils
 
convertPackagesToPaths(String[]) - Method in class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
convertProperties(String[]) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
convertProperty(Class, String) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
convertToBytes(Object, String) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Converts an XML in-memory representation to a String using a specific encoding.
convertToFile(Object) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
convertToHttpResponse(MuleMessage) - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
convertToText(Object) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Deprecated. Replaced by convertToText(Object obj, String ouputEncoding)
convertToText(Object, String) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Converts an XML in-memory representation to a String using a specific encoding.
COOKIE - Static variable in class org.mule.transport.tcp.protocols.SafeProtocol
 
COOKIE_SPEC_NETSCAPE - Static variable in class org.mule.transport.http.HttpConnector
 
COOKIE_SPEC_RFC2109 - Static variable in class org.mule.transport.http.HttpConnector
 
CookieHelper - Class in org.mule.transport.http
Helper functions for parsing, formatting, storing and retrieving cookie headers.
CookieWrapper - Class in org.mule.transport.http
 
CookieWrapper() - Constructor for class org.mule.transport.http.CookieWrapper
 
copy(MuleEvent) - Static method in class org.mule.DefaultMuleEvent
 
copy(InputStream, OutputStream) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
copy(InputStream, OutputStream) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
copy(XMLStreamReader, XMLStreamWriter) - Static method in class org.mule.module.xml.util.XMLUtils
Copies the reader to the writer.
copy(XMLStreamReader, XMLStreamWriter, boolean) - Static method in class org.mule.module.xml.util.XMLUtils
 
copy(InputStream, byte[], OutputStream) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Make a single transfer from source to dest via a byte array buffer
copy(InputStream, byte[], OutputStream, int) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Make a single transfer from source to dest via a byte array buffer
CopyAttachmentInInterceptor - Class in org.mule.module.cxf.support
 
CopyAttachmentInInterceptor() - Constructor for class org.mule.module.cxf.support.CopyAttachmentInInterceptor
 
CopyAttachmentOutInterceptor - Class in org.mule.module.cxf.support
Copies any attachments which were stored by the proxy to the outbound CXF message.
CopyAttachmentOutInterceptor() - Constructor for class org.mule.module.cxf.support.CopyAttachmentOutInterceptor
 
CopyAttachmentsTransformer - Class in org.mule.transformer.simple
 
CopyAttachmentsTransformer() - Constructor for class org.mule.transformer.simple.CopyAttachmentsTransformer
 
copyAttributes(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
copyBeanToTarget() - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Copy the properties from the bean we have been building into the target (typically the parent bean).
copyBeanToTarget() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Copy the properties from the bean we have been building into the target (typically the parent bean).
copyFile(File, File, boolean) - Static method in class org.mule.util.FileUtils
Copies a file to a new location.
copyHeaders(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
CopyInboundToOutboundPropertiesTransformerCallback - Class in org.mule.pattern.core.support
 
CopyInboundToOutboundPropertiesTransformerCallback() - Constructor for class org.mule.pattern.core.support.CopyInboundToOutboundPropertiesTransformerCallback
 
copyJMSProperties(Message, Message, JmsConnector) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
copyLarge(InputStream, OutputStream) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
copyLarge(InputStream, OutputStream) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
copyMessageProperties(MuleMessage) - Method in class org.mule.DefaultMuleMessage
 
copyOutboundProperties(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
copyParameters(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
CopyPropertiesTransformer - Class in org.mule.transformer.simple
 
CopyPropertiesTransformer() - Constructor for class org.mule.transformer.simple.CopyPropertiesTransformer
 
copyStream(InputStream, OutputStream) - Method in class org.mule.transport.tcp.protocols.StreamingProtocol
 
copyStreamToFile(InputStream, File) - Method in class org.mule.transport.sftp.SftpUtil
Should be moved to a util class that is not based on an endpoint...
copyStreamToFile(InputStream, File) - Static method in class org.mule.util.FileUtils
 
copyToInbound(DefaultMuleMessage) - Method in class org.mule.DefaultMuleMessage
copy outbound artifacts to inbound artifacts in the new message
CORE_EXTENSION_PROPERTIES - Static variable in class org.mule.module.launcher.MuleContainer
 
coreExtensions - Variable in class org.mule.module.launcher.application.PriviledgedMuleApplication
 
coreExtensions - Variable in class org.mule.module.launcher.MuleContainer
 
CoreMessages - Class in org.mule.config.i18n
 
CoreMessages() - Constructor for class org.mule.config.i18n.CoreMessages
 
CorePatternNamespaceHandler - Class in org.mule.pattern.core.config
Registers a Bean Definition Parser for handling elements.
CorePatternNamespaceHandler() - Constructor for class org.mule.pattern.core.config.CorePatternNamespaceHandler
 
CORRELATION_TIMEOUT - Static variable in class org.mule.context.notification.RoutingNotification
 
CorrelationMode - Enum in org.mule.routing
 
CorrelationPropertiesExpressionEvaluator - Class in org.mule.routing.correlation
CorrelationPropertiesExpressionEvaluator is a default implementation used for getting the Correlation information from a message.
CorrelationPropertiesExpressionEvaluator() - Constructor for class org.mule.routing.correlation.CorrelationPropertiesExpressionEvaluator
 
CorrelationSequenceComparator - Class in org.mule.routing.correlation
CorrelationSequenceComparator is a Comparator for MuleEvents using their respective correlation sequences.
CorrelationSequenceComparator() - Constructor for class org.mule.routing.correlation.CorrelationSequenceComparator
 
correlationTimedOut(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
CorrelationTimeoutException - Exception in org.mule.routing.correlation
 
CorrelationTimeoutException(Message, MuleEvent) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
 
CorrelationTimeoutException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
 
couldNotDetermineDestinationComponentFromEndpoint(String) - Static method in class org.mule.config.i18n.CoreMessages
 
couldNotFindEndpoint(QName, List<QName>) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
couldNotFindSoapProvider(String) - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
couldNotFindStreamWithName(ImmutableEndpoint) - Static method in class org.mule.transport.stdio.i18n.StdioMessages
 
couldNotInitAnnotationProcessor(Object) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
CouldNotRouteOutboundMessageException - Exception in org.mule.api.routing
CouldNotRouteOutboundMessageException thrown if Mule fails to route the current outbound event.
CouldNotRouteOutboundMessageException(MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
couldNotSendExpect100() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
count - Variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
count - Variable in class org.mule.tck.testmodels.services.TestComponent
 
count - Variable in class org.mule.tck.testmodels.services.TestReceiver
 
COUNT_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
CountdownCallback - Class in org.mule.tck.functional
 
CountdownCallback(int) - Constructor for class org.mule.tck.functional.CountdownCallback
 
Counter - Interface in org.mule.util.counters
This interface is the interface implemented for all counter types.
COUNTER_PROPERTY - Static variable in class org.mule.routing.Foreach
 
CounterCallback - Class in org.mule.tck.functional
A test callback that counts the number of messages received.
CounterCallback() - Constructor for class org.mule.tck.functional.CounterCallback
 
CounterCallback(AtomicInteger) - Constructor for class org.mule.tck.functional.CounterCallback
 
CounterFactory - Class in org.mule.util.counters
This class is the Counter's factory.
CounterFactory.Type - Class in org.mule.util.counters
Enum class for all different types of counters.
CounterFactory.Type(String) - Constructor for class org.mule.util.counters.CounterFactory.Type
Constructor of the type
CounterFactoryImpl - Class in org.mule.util.counters.impl
 
counterVariableName - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
countFailOrNullEvent() - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
CountingRedeliveryHandler - Class in org.mule.transport.jms.redelivery
This redelivery handler will keep counting the redelivery attempts for each message redelivered.
CountingRedeliveryHandler() - Constructor for class org.mule.transport.jms.redelivery.CountingRedeliveryHandler
 
CountingRedeliveryHandlerFactory - Class in org.mule.transport.jms.redelivery
 
CountingRedeliveryHandlerFactory() - Constructor for class org.mule.transport.jms.redelivery.CountingRedeliveryHandlerFactory
 
countRetry() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
CPU_J2EE - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CPU_SAMPLING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CPU_TRACING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CR - Static variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
create(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Method in interface org.mule.api.component.LifecycleAdapterFactory
 
create(Map<?, ?>) - Method in interface org.mule.api.config.PropertyFactory
Creates a property using code execution.
create(ServiceType, String, Properties, Properties, MuleContext, ClassLoader) - Static method in class org.mule.api.registry.ServiceDescriptorFactory
Factory method to create a new service descriptor.
create(Authentication) - Method in interface org.mule.api.security.SecurityContextFactory
 
create(MuleConfiguration) - Method in interface org.mule.api.transaction.TransactionManagerFactory
Creates of obtains the jta transaction manager to use for mule transactions
create(OutboundEndpoint) - Method in interface org.mule.api.transport.MessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in interface org.mule.api.transport.MessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(Object, String) - Method in interface org.mule.api.transport.MuleMessageFactory
Creates a MuleMessage instance from transportMessage by extracting its payload and, if available, any relevant message properties and attachments.
create(Object, MuleMessage, String) - Method in interface org.mule.api.transport.MuleMessageFactory
Creates a MuleMessage instance by extracting the payload from transportMessage.
create(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Method in class org.mule.component.DefaultComponentLifecycleAdapterFactory
 
create() - Method in interface org.mule.config.bootstrap.BootstrapObjectFactory
 
create(MuleContext) - Method in interface org.mule.config.dsl.Builder
 
create(Map<?, ?>) - Method in class org.mule.config.factories.HostNameFactory
 
create() - Method in interface org.mule.example.loanbroker.credit.CreditAgencyHome
 
create() - Method in class org.mule.module.atom.AbderaFactory
 
create(MuleContext, MuleIBeansPlugin) - Method in class org.mule.module.ibeans.config.IBeanHolder
 
create(MuleConfiguration) - Method in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
create(Authentication) - Method in class org.mule.module.pgp.PGPSecurityContextFactory
 
create(Authentication) - Method in class org.mule.module.spring.security.SpringSecurityContextFactory
 
create(MuleConfiguration) - Method in class org.mule.module.spring.transaction.SpringTransactionManagerFactory
 
create(Authentication) - Method in class org.mule.security.DefaultSecurityContextFactory
 
create(MuleConfiguration) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
create(MuleConfiguration) - Method in class org.mule.transaction.lookup.WebsphereTransactionManagerLookupFactory
This constructor retrieves the WebSphere TransactionManager factory class, so we can get access to the JTA TransactionManager.
create(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<? extends Collection>, Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<? extends Collection>, Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
create(Object, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
create(Object, MuleMessage, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ajax.AjaxMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ejb.EjbMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.email.RetrieveMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.email.SmtpMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.file.FileMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.file.FileMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ftp.FtpMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in class org.mule.transport.ftp.FtpMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.http.HttpClientMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in class org.mule.transport.http.HttpClientMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.http.HttpsClientMessageDispatcherFactory
 
create - Variable in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
create(OutboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcMessageRequesterFactory
 
create(String, Object) - Method in class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
create(String, Object) - Method in interface org.mule.transport.jdbc.sqlstrategy.SqlStatementStrategyFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.jms.JmsMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.jms.JmsMessageRequesterFactory
 
create() - Method in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
create() - Method in class org.mule.transport.jms.redelivery.CountingRedeliveryHandlerFactory
 
create() - Method in class org.mule.transport.jms.redelivery.JmsXRedeliveryHandlerFactory
 
create() - Method in interface org.mule.transport.jms.redelivery.RedeliveryHandlerFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
create(InboundEndpoint) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
create(OutboundEndpoint) - Method in class org.mule.transport.quartz.QuartzMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.rmi.RmiMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.sftp.SftpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.sftp.SftpMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcherFactory
 
create() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
create(InboundEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.soap.axis.wsdl.AxisWsdlMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.stdio.StdioMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.tcp.TcpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.tcp.TcpMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.udp.UdpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.udp.UdpMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.vm.VMMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.vm.VMMessageRequesterFactory
 
create(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.xmpp.XmppMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.xmpp.XmppMessageRequesterFactory
 
create(Class, Collection) - Static method in class org.mule.util.Multicaster
 
create(Class, Collection, Multicaster.InvokeListener) - Static method in class org.mule.util.Multicaster
 
create(Class[], Collection) - Static method in class org.mule.util.Multicaster
 
create(Class[], Collection, Multicaster.InvokeListener) - Static method in class org.mule.util.Multicaster
 
create() - Method in interface org.mule.util.xa.XAResourceFactory
 
CREATE_SOAP_FAULT - Static variable in class org.mule.module.cxf.CxfConstants
 
createAdaptor() - Method in class org.mule.module.management.agent.JdmkAgent
 
createAdaptor() - Method in class org.mule.module.management.agent.Mx4jAgent
 
createAlgorithmParameterSpec() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
createAlgorithmParameterSpec() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
createAlgorithmParameterSpec() - Method in class org.mule.security.SecretKeyEncryptionStrategy
 
createAnnotationsParserFactory() - Method in class org.mule.config.AnnotationsConfigurationBuilder
 
createAntStyleParser() - Static method in class org.mule.util.TemplateParser
 
createApp(String) - Method in interface org.mule.module.launcher.application.ApplicationFactory
Creates an application
createApp(String) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
createAppFrom(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
createAppFrom(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.PrivilegedApplicationFactory
 
createApplicationContext(MuleContext, ConfigResource[]) - Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
createApplicationContext(MuleContext, ConfigResource[]) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
createArchetype(String, String, String, ArtifactRepository, List, Map) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
createArgument(Class<?>, MuleContext) - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
If the resolver cannot locate the required object of type AbstractAnnotatedTransformerArgumentResolver.getArgumentClass() this method will be invoked an instance of the object.
createArgument(Class<?>, MuleContext) - Method in class org.mule.module.json.transformers.JsonMapperResolver
If the resolver cannot locate the required object of type AbstractAnnotatedTransformerArgumentResolver.getArgumentClass() this method will be invoked an instance of the object.
createArgument(Class, MuleContext) - Method in class org.mule.module.xml.transformer.jaxb.JAXBContextResolver
 
createArrayOf(String, Object[]) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createAsyncMessageProcessor(ProcessingStrategy.StageNameSource, MuleContext) - Method in class org.mule.construct.flow.DefaultFlowProcessingStrategy
 
createAsyncMessageProcessor(ProcessingStrategy.StageNameSource, MuleContext) - Method in class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
createAsyncMessageProcessor(ProcessingStrategy.StageNameSource, MuleContext) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
createAsyncReplyProcessor() - Method in class org.mule.service.AbstractService
 
createAuthentication(String, String, MuleEvent) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
createAxisProvider(String) - Method in class org.mule.transport.soap.axis.AxisConnector
 
createBeanDefinitionBuilder(Element, Class<?>) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
createBeanDefinitionBuilder(Element, Class<?>) - Method in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
createBeanDefinitionBuilder(Element, Class) - Method in class org.mule.config.spring.parsers.specific.endpoint.support.ChildEndpointDefinitionParser
 
createBeanFactory() - Method in class org.mule.config.spring.MuleApplicationContext
 
createBeginNotification(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
createBinding(String) - Method in class org.mule.module.ibeans.config.IntegrationBeanAnnotatedObjectProcessor
 
createBlob() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createBytesMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBytesMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBytesMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createChatConversation(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
createChildDefinitionParser(Class) - Static method in class org.mule.module.cxf.config.WsSecurityDefinitionParser
 
createClasspathScanner() - Method in class org.mule.module.ibeans.config.AbstractAnnotationConfigurationBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.LocalClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.SimpleClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
createClient(ImmutableEndpoint) - Static method in class org.mule.transport.sftp.SftpConnectionFactory
 
createClientFromLocalServer() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
createClob() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createConfigResourcesString() - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
createConfiguration() - Method in class org.mule.config.PropertiesMuleConfigurationFactory
 
createConfiguration(Set<Class<?>>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
createConfigurationBuilder() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
createConfigurationBuilder() - Method in class org.mule.MuleServer
 
createConfigurationBuilderFromApplicationProperties() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
createConnection() - Method in class org.mule.module.jca.DefaultMuleConnectionFactory
 
createConnection(MuleConnectionRequestInfo) - Method in class org.mule.module.jca.DefaultMuleConnectionFactory
 
createConnection() - Method in interface org.mule.module.jca.MuleConnectionFactory
 
createConnection(MuleConnectionRequestInfo) - Method in interface org.mule.module.jca.MuleConnectionFactory
 
createConnection(ConnectionFactory, String, String) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConnection(ConnectionFactory) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConnection(ConnectionFactory, String, String) - Method in class org.mule.transport.jms.Jms11Support
 
createConnection(ConnectionFactory) - Method in class org.mule.transport.jms.Jms11Support
 
createConnection() - Method in class org.mule.transport.jms.JmsConnector
 
createConnection(ConnectionFactory) - Method in interface org.mule.transport.jms.JmsSupport
 
createConnection(ConnectionFactory, String, String) - Method in interface org.mule.transport.jms.JmsSupport
 
createConnection() - Method in class org.mule.transport.jms.xa.ConnectionFactoryWrapper
 
createConnection(String, String) - Method in class org.mule.transport.jms.xa.ConnectionFactoryWrapper
 
createConnectionFactory(ConnectionManager) - Method in class org.mule.module.jca.MuleManagedConnectionFactory
Creates a Connection Factory instance.
createConnectionFactory() - Method in class org.mule.module.jca.MuleManagedConnectionFactory
Creates a Connection Factory instance.
createConnectionFactory() - Method in class org.mule.transport.jms.JmsConnector
 
createConnector(EndpointURI) - Method in class org.mule.config.endpoint.ConfigurableTransportFactory
 
createConnector - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
createConnector() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createConnector() - Method in class org.mule.transport.service.MetaTransportServiceDescriptor
Override the connector cration and register our Meta scheme with the connecotr so that the connector can be used when creating endpoints using this meta transport
createConnector(EndpointURI) - Method in class org.mule.transport.service.TransportFactory
Creates an uninitialied connector from the provided MuleEndpointURI.
createConnector(String) - Method in class org.mule.transport.service.TransportFactory
 
createConnector() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConsumer(Session, Destination, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createConsumer() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated. Create a consumer for the jms destination
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createConsumer(Session, Destination, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
Create a consumer for the jms destination
createContainerSystemClassLoader() - Method in class org.mule.module.reboot.MuleContainerWrapper
 
createContext(Resource) - Method in class org.mule.config.spring.jndi.SpringInitialContextFactory
 
createContextHolder(Connector, InboundEndpoint, MessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createCookie() - Method in class org.mule.transport.http.CookieWrapper
 
createCounter(String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public counter of the given type.
createCounter(String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new counter of the given type and visibility.
createCounter(String, String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public aggregate counter of the given type.
createCounter(String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new aggregate counter of the given type and visibility.
createCounter(String, String, String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public aggregate counter of the given type.
createCounter(String, String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new aggregate counter of the given type and visibility.
createCounter(String, String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.impl.CounterFactoryImpl
 
createCurlyBracesStyleParser() - Static method in class org.mule.util.TemplateParser
 
createDataBase(String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String[]) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String[], Properties) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataContentHandler(String) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
 
createDefaultInMemoryObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
 
createDefaultInMemoryObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultInMemoryObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultInMemoryQueueStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
 
createDefaultInMemoryQueueStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultInMemoryQueueStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultPersistentObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
 
createDefaultPersistentObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultPersistentObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultPersistentQueueStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
 
createDefaultPersistentQueueStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultPersistentQueueStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.endpoint.InboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.transport.Connector
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.transport.AbstractConnector
 
createDefaultUserObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
 
createDefaultUserObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultUserObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDelegate(QueueInfo, MuleContext) - Method in interface org.mule.util.queue.QueueInfo.QueueInfoDelegateFactory
Create a delegate
createDeleteMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createDeploymentClassLoader() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
createDestination(Session, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createDestination(Session, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createDispatcherFactory() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createDispatcherFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createDispatcherMessageProcessor(OutboundEndpoint) - Method in class org.mule.transport.AbstractConnector
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createEndpointBuilder(String) - Method in class org.mule.module.guice.AbstractMuleGuiceModule
Creates an EndpointBuilder instance for the endpoint uri.
createEndpointBuilder(String) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(EndpointURIEndpointBuilder) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(Object[]) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(String) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createEndpointBuilder(EndpointURIEndpointBuilder) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createEndpointData(Annotation) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
createEndpointData(Annotation) - Method in class org.mule.module.ibeans.config.CallAnnotationParser
 
createEndpointData(Annotation) - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
createEndpointInfo(ServiceInfo, BindingInfo, List<?>) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
createEndpointURIBuilder() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointURIBuilder() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createEnrichmentExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
createEntityMethod(MuleEvent, Object, EntityEnclosingMethod) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
createEntryPointResolverSet() - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
createErrorHandlingExecutionTemplate(MuleContext, MessagingExceptionHandler) - Static method in class org.mule.execution.ErrorHandlingExecutionTemplate
Creates a ErrorHandlingExecutionTemplate to be used as the main enthat will route any MessagingException thrown to an exception listener
createEventGroup(MuleEvent, Object) - Method in class org.mule.routing.correlation.CollectionCorrelatorCallback
Creates a new EventGroup that will expect the number of events as returned by MuleMessage.getCorrelationGroupSize().
createEventGroup(MuleEvent, Object) - Method in interface org.mule.routing.correlation.EventCorrelatorCallback
Creates the event group with a specific correlation size based on the Mule Correlation support
createEventToRoute(MuleEvent, MuleMessage, MessageProcessor) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Create a new event to be routed to the target MP
CreateException - Exception in org.mule.api.lifecycle
CreateException is thrown when creating an object inside Mule wasn't possible due to inconsistent internal state or wrong input.
CreateException(Message, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
CreateException(Message, Throwable, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
CreateException(Throwable, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
createExceptionTransformerExecutionTemplate() - Static method in class org.mule.execution.MessageProcessorExecutionTemplate
 
createExecutionTemplate() - Static method in class org.mule.execution.MessageProcessorExecutionTemplate
 
createExecutionTemplate() - Method in class org.mule.transport.AbstractMessageReceiver
 
createExpressionLanguageContext() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
createFactory(String, ClassLoader) - Static method in class org.apache.commons.logging.LogFactory
This method exists to ensure signature compatibility.
createFile() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
createFile(String) - Static method in class org.mule.util.FileUtils
 
createFilter(String) - Method in class org.mule.module.spring.events.MuleEventMulticaster
 
createFilter() - Method in class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppMessageTypeFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppOrFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppPacketIDFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppThreadFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppToContainsFilter
 
createFlowConstruct() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
createForDisjunctGroups(Element, Collection<CheckExclusiveAttributes.AttributeSet>) - Static method in exception org.mule.config.spring.parsers.processors.CheckExclusiveAttributes.CheckExclusiveAttributesException
 
createForInsufficientAttributes(Element, Collection<CheckExclusiveAttributes.AttributeSet>) - Static method in exception org.mule.config.spring.parsers.processors.CheckExclusiveAttributes.CheckExclusiveAttributesException
 
createFromField(Field) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromField(Field, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromMethodParam(Method, int) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodParam(Method, int, String) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodReturn(Method) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodReturn(Method, String) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromObject(Object) - Static method in class org.mule.transformer.types.DataTypeFactory
Will create a DataType object from an object instance.
createFromParameterType(Method, int) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromParameterType(Method, int, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromReturnType(Method) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromReturnType(Method, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFtpClient(ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
Creates a new FTPClient that logs in and changes the working directory using the data provided in endpoint.
createGetMethod(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createGetQuote() - Method in class net.webservicex.ObjectFactory
Create an instance of GetQuote
createGetQuoteResponse() - Method in class net.webservicex.ObjectFactory
Create an instance of GetQuoteResponse
createGroupchatConversation(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
createHeader(String, char[]) - Static method in class org.mule.security.MuleCredentials
 
createHeader(String, String, String, EncryptionStrategy) - Static method in class org.mule.security.MuleCredentials
 
createHeaders() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
createHeadMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createHelper(XmlReaderContext, Element, BeanDefinitionParserDelegate) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
createHelper(XmlReaderContext, Element) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
createImmutable(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createInboundMessage() - Method in interface org.mule.api.MuleMessage
Copy an inbound message to an outbound one, moving all message properties and attachments
createInboundMessage() - Method in class org.mule.DefaultMessageCollection
Copy an inbound message to an outbound one, moving all message properties and attachments
createInboundMessage() - Method in class org.mule.DefaultMuleMessage
 
createInboundMessageProcessorChain(InboundEndpoint, FlowConstruct, MessageProcessor) - Method in interface org.mule.api.endpoint.EndpointMessageProcessorChainFactory
 
createInboundMessageProcessorChain(InboundEndpoint, FlowConstruct, MessageProcessor) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
 
createInboundMessageProcessors(InboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createInboundResponseMessageProcessors(InboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createInboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createInboundTransformers(ImmutableEndpoint) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createInitialContext() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
Creates a JNDI context using the current AbstractJndiNameResolver.contextFactory
createInjector(Module...) - Static method in class org.guiceyfruit.mule.MuleModule
Returns a new Injector with support for Mule lifecycle support along with JSR 250 support included.
createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
 
createInstance() - Method in class org.mule.config.spring.factories.MuleTransactionManagerFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.ObjectStoreFromRegistryFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
createInstance() - Method in class org.mule.module.json.config.MapperFactoryBean
 
createInstance() - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
createInstance() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
createInstance() - Method in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
Create an instance using the discovery mechanism.
createInvocationHandler() - Method in class org.mule.module.ibeans.config.IBeanBinding
 
createInvoker(CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
createInvoker(CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
createJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
 
createJcaService(MessageEndpointFactory, JcaModel, InboundEndpoint) - Method in class org.mule.module.jca.MuleResourceAdapter
 
createJdkVersionRanges(String) - Static method in class org.mule.util.JdkVersionUtils
 
createJdmkAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createJettyConnector() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
createJettyConnector() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createJettyConnector() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
createJmsSupport() - Method in class org.mule.transport.jms.JmsConnector
A factory method to create various JmsSupport class versions.
createJmxAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createJmxNotificationAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createKeySpec() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
createKeySpec() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
createKeySpec() - Method in class org.mule.security.SecretKeyEncryptionStrategy
 
createLifecycleAdaptor() - Method in class org.mule.component.AbstractJavaComponent
Creates and initialises a new LifecycleAdaptor instance wrapped the component object instance obtained from the configured object factory.
createLifecycleManager() - Method in class org.mule.config.spring.SpringRegistry
 
createLifecycleManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createLifecycleManager() - Method in class org.mule.registry.AbstractRegistry
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageDispatcher
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageReceiver
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageRequester
 
createLifecycleManager() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
createLifecycleState() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
createLog4jAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createMainExecutionTemplate(MuleContext, MessagingExceptionHandler) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
Creates a TransactionalErrorHandlingExecutionTemplate to be used as first processing template in a flow using no transaction configuration
createMainExecutionTemplate(MuleContext, TransactionConfig, MessagingExceptionHandler) - Static method in class org.mule.execution.