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(Executor) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
abort(Executor) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
abort() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Abort if authentication fails
abort(Executor) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
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.
AbstractAddVariablePropertyTransformer - Class in org.mule.transformer.simple
 
AbstractAddVariablePropertyTransformer() - Constructor for class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
AbstractAdvancedDbProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
AbstractAdvancedDbProcessorDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
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
 
AbstractAnnotatedObject - Class in org.mule
Base implementation for AnnotatedObject
AbstractAnnotatedObject() - Constructor for class org.mule.AbstractAnnotatedObject
 
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
 
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
 
AbstractArtifactClassLoader - Class in org.mule.module.launcher.artifact
Abstract implementation of the ArtifactClassLoader interface, that manages shutdown listeners.
AbstractArtifactClassLoader(URL[], ClassLoader) - Constructor for class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
AbstractArtifactClassLoader(URL[], ClassLoader, Set<String>) - Constructor for class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
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
 
AbstractAuthorizationCodeTokenRequestHandler - Class in org.mule.module.oauth2.internal.authorizationcode
Base class for token request handler.
AbstractAuthorizationCodeTokenRequestHandler() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
AbstractAuthorizeMessageProcessor - Class in org.mule.security.oauth.processor
 
AbstractAuthorizeMessageProcessor() - Constructor for class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
AbstractBaseOptionsBuilder<BuilderType extends AbstractBaseOptionsBuilder,OptionsType> - Class in org.mule.api.client
Base options for every operation.
AbstractBaseOptionsBuilder() - Constructor for class org.mule.api.client.AbstractBaseOptionsBuilder
 
AbstractBulkQueryResolver - Class in org.mule.module.db.internal.resolver.query
Base class for BulkQueryResolver implementations
AbstractBulkQueryResolver(String, QueryTemplateParser) - Constructor for class org.mule.module.db.internal.resolver.query.AbstractBulkQueryResolver
 
AbstractBulkUpdateMessageProcessor - Class in org.mule.module.db.internal.processor
Defines a base class for single query bulk update operations
AbstractBulkUpdateMessageProcessor(DbConfigResolver, TransactionalAction, List<QueryType>, QueryResolver, BulkQueryExecutorFactory) - Constructor for class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
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
Deprecated.
AbstractCatchAllStrategy() - Constructor for class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
 
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
 
AbstractConnectionFactory - Class in org.mule.module.db.internal.domain.connection
Base class for ConnectionFactory
AbstractConnectionFactory() - Constructor for class org.mule.module.db.internal.domain.connection.AbstractConnectionFactory
 
AbstractConnectionFactoryDecorator - Class in org.mule.transport.jms
Base class for every ConnectionFactoryDecorator to apply consistent behavior.
AbstractConnectionFactoryDecorator() - Constructor for class org.mule.transport.jms.AbstractConnectionFactoryDecorator
 
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
 
AbstractConsumer<T,P> - Class in org.mule.streaming
Base implementation of Consumer.
AbstractConsumer(Producer<P>) - Constructor for class org.mule.streaming.AbstractConsumer
 
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
 
AbstractDataQualifierVisitor - Class in org.mule.module.extension.internal.introspection
Base implementation of DataQualifierVisitor in which all methods are implemented and delegate into AbstractDataQualifierVisitor.defaultOperation().
AbstractDataQualifierVisitor() - Constructor for class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
AbstractDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
AbstractDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
AbstractDbConfigResolver - Class in org.mule.module.db.internal.resolver.database
Provides a base implementation for resolver's metadata related functionality
AbstractDbConfigResolver() - Constructor for class org.mule.module.db.internal.resolver.database.AbstractDbConfigResolver
 
AbstractDbConnection - Class in org.mule.module.db.internal.domain.connection
Implements connector side of DbConnection
AbstractDbConnection(Connection, TransactionalAction, DefaultDbConnectionReleaser, ParamTypeResolverFactory) - Constructor for class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
AbstractDbMessageProcessor - Class in org.mule.module.db.internal.processor
Base class for database message processors.
AbstractDbMessageProcessor(DbConfigResolver, TransactionalAction) - Constructor for class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
AbstractDbProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
AbstractDbProcessorDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
AbstractDbType - Class in org.mule.module.db.internal.domain.type
Base class for DbType
AbstractDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.AbstractDbType
 
AbstractDebugQueryLogger - Class in org.mule.module.db.internal.domain.logger
Base class for query loggers that write to a logger
AbstractDebugQueryLogger(Log) - Constructor for class org.mule.module.db.internal.domain.logger.AbstractDebugQueryLogger
 
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
 
AbstractDevkitBasedDefinitionParser - Class in org.mule.security.oauth.config
 
AbstractDevkitBasedDefinitionParser() - Constructor for class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
AbstractDevkitBasedDefinitionParser.ParseDelegate<T> - Interface in org.mule.security.oauth.config
 
AbstractDevkitBasedPageableMessageProcessor - Class in org.mule.streaming.processor
Base class for devkit generated pageable message processors.
AbstractDevkitBasedPageableMessageProcessor(String) - Constructor for class org.mule.streaming.processor.AbstractDevkitBasedPageableMessageProcessor
 
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
 
AbstractEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
AbstractEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.AbstractEnricherDataTypePropagator
 
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
 
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.
AbstractExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractExceptionStrategy
Deprecated.
 
AbstractExecutor - Class in org.mule.module.db.internal.domain.executor
Base class for query executors
AbstractExecutor(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
AbstractExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Base class for extracting data type from CompiledExpression
AbstractExpressionDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.AbstractExpressionDataTypeResolver
 
AbstractExpressionEvaluator - Class in org.mule.expression
Base class for ExpressionEvaluator which provides an implementation of #evaluateTyped (String, MuleMessage) returning a default data type.
AbstractExpressionEvaluator() - Constructor for class org.mule.expression.AbstractExpressionEvaluator
 
AbstractExpressionEvaluator - Class in org.mule.security.oauth.processor
Deprecated.
AbstractExpressionEvaluator() - Constructor for class org.mule.security.oauth.processor.AbstractExpressionEvaluator
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
 
AbstractFakeMuleServerTestCase - Class in org.mule.test.infrastructure.deployment
 
AbstractFakeMuleServerTestCase() - Constructor for class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
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
 
AbstractGrantType - Class in org.mule.module.oauth2.internal
Common interface for all grant types must extend this interface.
AbstractGrantType() - Constructor for class org.mule.module.oauth2.internal.AbstractGrantType
 
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
 
AbstractInstant - Class in org.mule.el.datetime
 
AbstractInstant(Calendar, Locale) - Constructor for class org.mule.el.datetime.AbstractInstant
 
AbstractInstant() - Constructor for class org.mule.el.datetime.AbstractInstant
 
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
 
AbstractJmxAgent - Class in org.mule.module.management.agent
AbstractJmxAgent registers Mule Jmx management beans with an MBean server.
AbstractJmxAgent() - Constructor for class org.mule.module.management.agent.AbstractJmxAgent
 
AbstractJmxAgent.MuleContextStartedListener - Class in org.mule.module.management.agent
 
AbstractJmxAgent.MuleContextStartedListener() - Constructor for class org.mule.module.management.agent.AbstractJmxAgent.MuleContextStartedListener
 
AbstractJmxAgent.MuleContextStoppedListener - Class in org.mule.module.management.agent
 
AbstractJmxAgent.MuleContextStoppedListener() - Constructor for class org.mule.module.management.agent.AbstractJmxAgent.MuleContextStoppedListener
 
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
 
AbstractListeningMessageProcessor - Class in org.mule.security.oauth.processor
 
AbstractListeningMessageProcessor(String) - Constructor for class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
 
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
 
AbstractMapStatementResultHandler - Class in org.mule.module.db.internal.result.statement
Processes Statement results creating a map containing them.
AbstractMapStatementResultHandler(ResultSetHandler) - Constructor for class org.mule.module.db.internal.result.statement.AbstractMapStatementResultHandler
 
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
Deprecated.
AbstractModel() - Constructor for class org.mule.model.AbstractModel
Deprecated.
 
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 customizing 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
 
AbstractMuleEventWork(MuleEvent, boolean) - Constructor for class org.mule.work.AbstractMuleEventWork
Constructor allowing event copying to be disabled.
AbstractMuleGuiceModule - Class in org.mule.module.guice
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
AbstractMuleGuiceModule() - Constructor for class org.mule.module.guice.AbstractMuleGuiceModule
Deprecated.
 
AbstractMuleMessageFactory - Class in org.mule.transport
 
AbstractMuleMessageFactory() - Constructor for class org.mule.transport.AbstractMuleMessageFactory
Required by subclasses to instantiate factory through reflection.
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
 
AbstractMuleNamespaceHandler.IgnoredDefinitionParser - Class in org.mule.config.spring.handlers
 
AbstractMuleNamespaceHandler.IgnoredDefinitionParser() - Constructor for class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler.IgnoredDefinitionParser
 
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
 
AbstractMultipleProcessTestCase - Class in org.mule.test.infrastructure.process
 
AbstractMultipleProcessTestCase() - Constructor for class org.mule.test.infrastructure.process.AbstractMultipleProcessTestCase
 
AbstractNamedEncryptionStrategy - Class in org.mule.security
 
AbstractNamedEncryptionStrategy() - Constructor for class org.mule.security.AbstractNamedEncryptionStrategy
 
AbstractNonBlockingMessageProcessor - Class in org.mule.processor
Abstract implementation of NonBlockingMessageProcessor that determines if processing should be performed blocking or non-blocking..
AbstractNonBlockingMessageProcessor() - Constructor for class org.mule.processor.AbstractNonBlockingMessageProcessor
 
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
 
AbstractNullQueryLogger - Class in org.mule.module.db.internal.domain.logger
Base class for query loggers that logs nothing
AbstractNullQueryLogger() - Constructor for class org.mule.module.db.internal.domain.logger.AbstractNullQueryLogger
 
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
 
AbstractObjectSerializer - Class in org.mule.serialization.internal
Base class for implementations of ObjectSerializer This class implements all the base behavioral contract allowing its extensions to only care about the actual serialization/deserialization part.
AbstractObjectSerializer() - Constructor for class org.mule.serialization.internal.AbstractObjectSerializer
 
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
 
AbstractParamDefinitionDefinitionParser - Class in org.mule.module.db.internal.config.domain.param
 
AbstractParamDefinitionDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
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 MessageProcessors 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
 
AbstractProxyGZIPInterceptor - Class in org.mule.module.cxf.support
 
AbstractProxyGZIPInterceptor(String) - Constructor for class org.mule.module.cxf.support.AbstractProxyGZIPInterceptor
 
AbstractQueryMetadataProvider - Class in org.mule.module.db.internal.metadata
Base class for QueryMetadataProvider implementations
AbstractQueryMetadataProvider(DbConfigResolver, Query) - Constructor for class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
AbstractQueryParam - Class in org.mule.module.db.internal.domain.param
Defines a base class for implementing different kind of { @link QueryParam} classes.
AbstractQueryParam(int, DbType, String) - Constructor for class org.mule.module.db.internal.domain.param.AbstractQueryParam
 
AbstractQueueManager - Class in org.mule.util.queue
Abstract implementation for a QueueManager.
AbstractQueueManager() - Constructor for class org.mule.util.queue.AbstractQueueManager
 
AbstractQueueSession - Class in org.mule.util.queue
 
AbstractQueueSession(QueueProvider, MuleContext) - Constructor for class org.mule.util.queue.AbstractQueueSession
 
AbstractQueueStoreDelegate - Class in org.mule.util.queue
Abstract queue delegate implementation that forces common queue behaviour
AbstractQueueStoreDelegate(int) - Constructor for class org.mule.util.queue.AbstractQueueStoreDelegate
 
AbstractQueueStoreFactoryBean - Class in org.mule.config.spring.factories
 
AbstractQueueStoreFactoryBean(String) - Constructor for class org.mule.config.spring.factories.AbstractQueueStoreFactoryBean
 
AbstractQueueTransactionJournal<T,K extends JournalEntry<T>> - Class in org.mule.util.journal.queue
Base implementation for a queue transaction journal.
AbstractQueueTransactionJournal(String, JournalEntrySerializer) - Constructor for class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
AbstractQueueTxJournalEntry<T> - Class in org.mule.util.journal.queue
Base implementation for a queue JournalEntry.
AbstractQueueTxJournalEntry(T, byte, String, Serializable) - Constructor for class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
AbstractQueueTxJournalEntry(T, byte) - Constructor for class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
AbstractQueueTxJournalEntry(DataInputStream, MuleContext) - Constructor for class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
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
 
AbstractRegistryBootstrap - Class in org.mule.config.bootstrap
Base class for an object will load objects defined in a file called registry-bootstrap.properties into the local registry.
AbstractRegistryBootstrap() - Constructor for class org.mule.config.bootstrap.AbstractRegistryBootstrap
Creates a default SimpleRegistryBootstrap using a ClassPathRegistryBootstrapDiscoverer in order to get the Properties resources from the class path.
AbstractRegistryBootstrap(RegistryBootstrapDiscoverer) - Constructor for class org.mule.config.bootstrap.AbstractRegistryBootstrap
Allows to specify a RegistryBootstrapDiscoverer to discover the Properties resources to be used.
AbstractRegistryBroker - Class in org.mule.registry
Deprecated.
as of 3.7.0. This will be removed in Mule 4.0
AbstractRegistryBroker(MuleContext) - Constructor for class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
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
 
AbstractRequestResponseMessageProcessor - Class in org.mule.processor
Base implementation of a MessageProcessor that may performs processing during both the request and response processing phases while supporting non-blocking execution.
AbstractRequestResponseMessageProcessor() - Constructor for class org.mule.processor.AbstractRequestResponseMessageProcessor
 
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.queue.objectstore.xa
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
AbstractResourceManager() - Constructor for class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
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
 
AbstractResourcesGenerator - Class in org.mule.module.extension.internal.resources
Base implementation of ResourcesGenerator that takes care of the basic contract except for actually writing the resources to a persistent store.
AbstractResourcesGenerator(ServiceRegistry) - Constructor for class org.mule.module.extension.internal.resources.AbstractResourcesGenerator
 
AbstractResultSetHandlerProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
AbstractResultSetHandlerProcessorDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.AbstractResultSetHandlerProcessorDefinitionParser
 
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
 
AbstractRoutingStrategy - Class in org.mule.routing
Abstract routing strategy with utility methods to be reused by routing strategies
AbstractRoutingStrategy(MuleContext) - Constructor for class org.mule.routing.AbstractRoutingStrategy
 
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
 
AbstractSecurityStrategy - Class in org.mule.module.ws.security
 
AbstractSecurityStrategy() - Constructor for class org.mule.module.ws.security.AbstractSecurityStrategy
 
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
Deprecated.
AbstractService(MuleContext) - Constructor for class org.mule.service.AbstractService
Deprecated.
 
AbstractServiceAndFlowTestCase - Class in org.mule.tck
Deprecated.
AbstractServiceAndFlowTestCase(AbstractServiceAndFlowTestCase.ConfigVariant, String) - Constructor for class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
AbstractServiceAndFlowTestCase.ConfigVariant - Enum in org.mule.tck
Deprecated.
 
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
 
AbstractSessionHandler - Class in org.mule.session
Base class for implementations of SessionHandler which adds common functionality, specially around the concept of serialization
AbstractSessionHandler() - Constructor for class org.mule.session.AbstractSessionHandler
 
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
 
AbstractSingleQueryDbMessageProcessor - Class in org.mule.module.db.internal.processor
Base class for message processors processing only one query
AbstractSingleQueryDbMessageProcessor(DbConfigResolver, QueryResolver, TransactionalAction) - Constructor for class org.mule.module.db.internal.processor.AbstractSingleQueryDbMessageProcessor
 
AbstractSingleQueryExecutor - Class in org.mule.module.db.internal.domain.executor
Base class for executors that execute a single query
AbstractSingleQueryExecutor(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
AbstractSingleQueryProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
AbstractSingleQueryProcessorDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
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
 
AbstractStreamingResultSetCloser - Class in org.mule.module.db.internal.result.statement
Base class for implementing StreamingResultSetCloser
AbstractStreamingResultSetCloser() - Constructor for class org.mule.module.db.internal.result.statement.AbstractStreamingResultSetCloser
 
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
 
AbstractThreadingProfileProcessingStrategy - Class in org.mule.processor.strategy
A abstract ProcessingStrategy implementation that provides a ThreadingProfile for you in extensions configured via setters for each of the threading profile attributes.
AbstractThreadingProfileProcessingStrategy() - Constructor for class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
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
 
AbstractTokenRequestHandler - Class in org.mule.module.oauth2.internal
 
AbstractTokenRequestHandler() - Constructor for class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
AbstractTokenRequestHandler.TokenUrlResponseException - Exception in org.mule.module.oauth2.internal
 
AbstractTokenRequestHandler.TokenUrlResponseException(MuleEvent) - Constructor for exception org.mule.module.oauth2.internal.AbstractTokenRequestHandler.TokenUrlResponseException
 
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.queue.objectstore.xa
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
AbstractTransactionContext() - Constructor for class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
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
 
AbstractTransportMessageProcessTemplate<MessageReceiverType extends AbstractMessageReceiver,ConnectorType extends AbstractConnector> - Class in org.mule.transport
 
AbstractTransportMessageProcessTemplate(MessageReceiverType) - Constructor for class org.mule.transport.AbstractTransportMessageProcessTemplate
 
AbstractUntilSuccessfulProcessingStrategy - Class in org.mule.routing
Abstract class with common logic for until successful processing strategies.
AbstractUntilSuccessfulProcessingStrategy() - Constructor for class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
AbstractUpdateProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
AbstractUpdateProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.AbstractUpdateProcessorBeanDefinitionParser
 
AbstractVariableEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Base class EnricherDataTypePropagator that propagate data type to message properties.
AbstractVariableEnricherDataTypePropagator(String, PropertyScope) - Constructor for class org.mule.el.mvel.datatype.AbstractVariableEnricherDataTypePropagator
 
AbstractVariableExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Base class for extracting data type from map variables
AbstractVariableExpressionDataTypeResolver(String, PropertyScope) - Constructor for class org.mule.el.mvel.datatype.AbstractVariableExpressionDataTypeResolver
 
AbstractVendorConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.database
Base class for creating vendor's DbConfigResolverFactoryBean
AbstractVendorConfigResolverFactoryBean(String, ConfigurableDbConfigFactory) - Constructor for class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
AbstractWebServiceWrapperComponent - Class in org.mule.module.cxf.component
 
AbstractWebServiceWrapperComponent() - Constructor for class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
AbstractXAResourceManager - Class in org.mule.util.queue.objectstore.xa
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
AbstractXAResourceManager() - Constructor for class org.mule.util.queue.objectstore.xa.AbstractXAResourceManager
Deprecated.
 
AbstractXAResourceManager<T extends AbstractXaTransactionContext> - Class in org.mule.util.xa
 
AbstractXAResourceManager() - Constructor for class org.mule.util.xa.AbstractXAResourceManager
 
AbstractXaTransactionContext - Class in org.mule.util.xa
Base transaction context for XA transactions
AbstractXaTransactionContext() - Constructor for class org.mule.util.xa.AbstractXaTransactionContext
 
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
Deprecated.
this base class is deprecated. Use XPath3Function instead
AbstractXPathExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
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(MuleEvent) - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
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 - Static variable in class org.mule.module.http.api.HttpHeaders.Names
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.JsonSchemaJsonValidationFilter
Deprecated.
 
accept(MuleMessage) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
accept(MuleMessage) - Method in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
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
Deprecated.
 
accept(MuleMessage) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
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
Deprecated.
Should the annotation represented by an AnnotationInfo object be accepted
accept(AnnotationInfo) - Method in class org.mule.util.scan.annotations.AnnotationTypeFilter
Deprecated.
 
accept(AnnotationInfo) - Method in class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
Deprecated.
 
ACCEPT_CHARSET - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCEPT_ENCODING - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCEPT_LANGUAGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCEPT_PATCH - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCEPT_RANGES - Static variable in class org.mule.module.http.api.HttpHeaders.Names
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.ChoiceMessagingExceptionStrategy
 
acceptsAll() - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
acceptsAll() - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
AcceptsAllMethodsRequestMatcher - Class in org.mule.module.http.internal.listener.matcher
Accepts all the http methods
acceptsEvent(MuleEvent) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
Always accept MessageRedeliveryException exceptions if this rollback exception strategy handles redelivery.
acceptsEvent(MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
Determines if the exception strategy should process or not a message inside a choice exception strategy.
acceptValue(Object) - Method in class org.mule.transport.polling.watermark.selector.ComparableWatermarkSelector
 
acceptValue(Object) - Method in class org.mule.transport.polling.watermark.selector.FirstItemWatermarkSelector
 
acceptValue(Object) - Method in class org.mule.transport.polling.watermark.selector.LastItemWatermarkSelector
 
acceptValue(Object) - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelector
Receives a value which is candidate to become the new watermark value.
acceptValue(Object) - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelectorWrapper
 
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_MAX_AGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ACCESS_TOKEN_EXPRESSION - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
ACCESS_TOKEN_ID - Static variable in interface org.mule.security.oauth.OAuthProperties
 
ACCESS_TOKEN_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
ACCESS_TOKEN_URL - Static variable in class org.mule.security.oauth.BaseOAuth2Manager
 
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
 
acquireAccessToken(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Borrow an access token from the pool
acquireAccessToken(String) - Method in interface org.mule.security.oauth.OAuth2Manager
Borrow an access token from the pool
acquireMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
This method will only be called once for the MessageProcessContext
acquireMessage() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
acquireMessage() - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
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
Deprecated.
 
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
Deprecated.
 
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
Deprecated.
 
ACTION_SEND - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
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
Deprecated.
 
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(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
This default implementation does nothing
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.queue.objectstore.xa.AbstractXAResourceManager
Deprecated.
 
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(QueryTemplate) - Method in class org.mule.module.db.internal.domain.query.BulkQuery
Adds a new query template to the bulk
add(Parameter, ValueResolver) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSet
Links the given ValueResolver to the given Parameter.
add(Parameter, Object) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult.Builder
Adds a new result value for the given parameter
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
 
add(Serializable) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
Adds an item at the end of the queue
add(Serializable) - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
add(Serializable) - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
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.AbstractQueueStoreDelegate
 
addAll(Collection<? extends Serializable>) - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
addAll(Collection<? extends Serializable>) - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Appends all of the elements in the specified collection to the queue (optional operation).
addAll(Collection<? extends Serializable>) - Method in interface org.mule.util.queue.QueueStoreDelegate
Appends all of the elements in the specified collection to the queue (optional operation).
addAllListenerSubscriptionPairs(Collection<?>) - Method in class org.mule.context.notification.ServerNotificationManager
Deprecated.
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
 
addAnnotationsConfigBuilderIfPresent(List<ConfigurationBuilder>) - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
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.
addAppArchive(URL) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Copies a given app archive to the apps folder for deployment.
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
Deprecated.
Adds a listener to the the Multicaster.
addApplicationListenerBean(String) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
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
addAttachment(String, DataHandler) - Method in class org.mule.DefaultMuleMessage
Deprecated.
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
 
addBreakpoint(Breakpoint) - Method in interface org.mule.api.debug.BreakpointManager
Adds a breakpoint to the current set of breakpoints.
addBuilders(List<ConfigurationBuilder>) - Method in class org.mule.tck.junit4.ExtensionsFunctionalTestCase
Adds a ConfigurationBuilder that sets the ExtensionsFunctionalTestCase.extensionManager into the AbstractMuleContextTestCase.muleContext.
addCallbackHandler(CallbackHandler) - Method in class org.mule.module.ws.security.CompositeCallbackHandler
 
addCapability(Object) - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
 
addChild(MessageProcessor) - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
addChild(String) - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
addChild(MessageProcessorPathElement) - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
addChild(MessageProcessor) - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
addChild(String) - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
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
 
addChildPathMap(String, HttpListenerRegistry.PathMap) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
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
Deprecated.
 
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.util.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 branch 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
addConfigurationAttribute(String, String) - Method in interface org.mule.test.infrastructure.process.ConfigurableProcessBuilder
 
addConfigurationAttribute(String, String) - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
addContentLenght(String) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
addContentType(String) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
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.
addCoreExtension(MuleCoreExtension) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
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.util.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 interface org.mule.module.launcher.DeploymentListenerManager
 
addDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
addDeploymentListener(DeploymentListener) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
addDestinationProperty(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
addDirectTransition(String, String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
addDomainDeploymentListener(DeploymentListener) - Method in interface org.mule.module.launcher.DomainDeploymentListenerManager
 
addDomainDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
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
 
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
 
addExecutedProcessors(String) - Method in class org.mule.context.notification.DefaultProcessorsTrace
Adds a message processor path to the list of processors that were executed as part of the processing of this event.
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.
addExecutor(ServerAddress, WorkManagerSource) - Method in class org.mule.module.http.internal.listener.grizzly.WorkManagerSourceExecutorProvider
Adds an Executor to be used when a request is made to a ServerAddress
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<File>) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
 
addFiles(List<File>) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addFilterForAddress(ServerAddress, F) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
Adds a new Filter for a particular Server address
addFinalVariable(String, T) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
addFinalVariable(String, T) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addFirst(Serializable) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
Adds an object at the beginning of the queue
addFirst(Serializable) - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
addFirst(Serializable) - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
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(Handler) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
addHeader(String, String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
addHeader(String, Object) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
addHeader(String, String) - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
addHeader(String, Object) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
addHeader(String, String) - Method in class org.mule.module.http.internal.multipart.HttpPart
 
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
 
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
 
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
 
addLibrary(File) - Method in class org.mule.test.infrastructure.process.Controller
 
addLibrary(File) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
addLibraryDirectory(File, String) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
addLifecycleCallback(FunctionalTestComponent.LifecycleCallback) - Static method in class org.mule.tck.functional.FunctionalTestComponent
 
addListener(MuleContextListener) - Method in interface org.mule.api.context.MuleContextFactory
Adds a listener to be notified of each event related to the creation of a new MuleContext
addListener(MuleContextListener) - Method in class org.mule.context.DefaultMuleContextFactory
 
addListener(ServerNotificationListener<?>) - Method in class org.mule.context.notification.ServerNotificationManager
 
addListener(Callback<MuleEvent>) - Method in class org.mule.tck.listener.FlowExecutionListener
 
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<String, Object>) - 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<String, Object>) - 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
Deprecated.
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in interface org.mule.api.processor.MessageProcessorContainer
Add the child nodes to the path element tree.
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.construct.AbstractPipeline
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.enricher.MessageEnricher
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.chain.SubflowInterceptingChainLifecycleWrapper
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.routing.AbstractSelectiveRouter
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.routing.Foreach
 
addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
 
addMessageProcessorPathElements(List<MessageProcessor>, MessageProcessorPathElement) - Static method in class org.mule.util.NotificationUtils
 
addMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.model.seda.SedaService
Deprecated.
 
addMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.service.AbstractService
Deprecated.
 
addMessages(MuleMessage[]) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(MuleEvent[]) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(List<MuleMessage>) - Method in interface org.mule.api.MuleMessageCollection
 
addMessages(MuleEvent[]) - Method in class org.mule.DefaultMessageCollection
 
addMessages(List<MuleMessage>) - Method in class org.mule.DefaultMessageCollection
 
addMessages(MuleMessage[]) - Method in class org.mule.DefaultMessageCollection
 
addMetadataAnnotationsFromXml(Map<QName, Object>, String, int, String) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
Populates the passed beanAnnotations with the other passed parameters.
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
Deprecated.
 
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
 
addPacketListener(PacketListener) - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
addPacketListener(PacketListener) - Method in interface org.mule.transport.xmpp.XmppConversation
Adds listener to this conversation's XMPP connection.
addParameter(InputQueryParam, Object) - Method in class org.mule.module.db.internal.domain.logger.DebugSingleQueryLogger
 
addParameter(InputQueryParam, Object) - Method in class org.mule.module.db.internal.domain.logger.NullSingleQueryLogger
 
addParameter(InputQueryParam, Object) - Method in interface org.mule.module.db.internal.domain.logger.SingleQueryLogger
Adds the value of a query parameter for logging
addParameter(String, Field) - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
Adds a parameter to the group
addParameterSet() - Method in class org.mule.module.db.internal.domain.logger.DebugPreparedBulkQueryLogger
 
addParameterSet() - Method in class org.mule.module.db.internal.domain.logger.NullPreparedBulkQueryLogger
 
addParameterSet() - Method in interface org.mule.module.db.internal.domain.logger.PreparedBulkQueryLogger
Adds another set of parameters to the bulk query logger
addParamToContext(String, Object, VelocityContext) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
addPart(Object, OutboundEndpoint) - Method in class org.mule.routing.outbound.SplitMessage
 
addPasswordCallbackHandler(Map<String, Object>, WSPasswordCallbackHandler) - Method in class org.mule.module.ws.security.AbstractSecurityStrategy
Adds a password callback to a config properties map, allowing to compose many handlers from different security strategies.
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
 
addPluginClassLoader(ClassLoader) - Method in class org.mule.module.launcher.MulePluginClassLoaderManager
 
addPluginClassLoader(ClassLoader) - Method in interface org.mule.module.launcher.PluginClassLoaderManager
Adds a new classloader
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
 
addPrivateVariable(String, T) - Method in interface org.mule.api.el.ExpressionLanguageContext
Deprecated.
addPrivateVariable(String, T) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
addProcessBuilderConfigurer(ProcessBuilderConfigurer) - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
addProcessed(Object) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
addProcessedGroup(Object) - Method in class org.mule.routing.correlation.EventCorrelator
 
addProcessingTime(ProcessingTime) - Method in class org.mule.management.stats.DefaultProcessingTimeWatcher
 
addProcessingTime(ProcessingTime) - Method in interface org.mule.management.stats.ProcessingTimeWatcher
Adds a new instance to watch
addProperties(Map<String, Object>) - Method in interface org.mule.api.MuleMessage
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.jetty.JettyMuleMessageFactory
 
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
 
addPropertiesTo(Map<String, Object>) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
addPropertyChangeListener(PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
addPropertyChangeListener(String, PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
addPropertyResolver(Field, ValueResolver<? extends Object>) - Method in interface org.mule.module.extension.internal.runtime.ObjectBuilder
Adds a property which value is to be obtained from a ValueResolver
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
 
addQuery(String) - Method in interface org.mule.module.db.internal.domain.logger.BulkQueryLogger
Adds a new query to log
addQuery(String) - Method in class org.mule.module.db.internal.domain.logger.DebugBulkQueryLogger
 
addQuery(String) - Method in class org.mule.module.db.internal.domain.logger.NullBulkQueryLogger
 
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
Deprecated.
as of 3.7.0. This will be removed in Mule 4.0
addRegistry(Registry) - Method in interface org.mule.api.registry.RegistryBroker
Deprecated.
 
addRegistry(Registry) - Method in class org.mule.DefaultMuleContext
Deprecated.
addRegistry(Registry) - Method in class org.mule.registry.DefaultRegistryBroker
Deprecated.
 
addReplyToProperty(DefaultMuleMessage, Message) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
addRequestHandler(ListenerRequestMatcher, RequestHandler) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
addRequestHandler(ListenerRequestMatcher, RequestHandler) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
addRequestHandler(Server, RequestHandler, ListenerRequestMatcher) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry
 
addRequestHandler(ListenerRequestMatcher, RequestHandler) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.ServerAddressRequestHandlerRegistry
 
addRequestHandler(ListenerRequestMatcher, RequestHandler) - Method in interface org.mule.module.http.internal.listener.Server
 
addRequestHandlerMatcherPair(HttpListenerRegistry.RequestHandlerMatcherPair) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
addResolver(String, VariableResolver) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
addResources(List<ConfigResource>) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
Template method for modifying the list of resources to be loaded.
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
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
Deprecated.
 
addRoute(MessageProcessor) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
addRoute(MessageProcessor) - Method in class org.mule.routing.outbound.OutboundPassThroughRouter
Deprecated.
 
addRoute(MessageProcessor) - Method in class org.mule.routing.ScatterGatherRouter
Adds a new message processor to the list of routes
addRouterForInterface(InterfaceBinding) - Method in class org.mule.component.BindingInvocationHandler
 
addSchedulerFactoryProperty(String, String) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
addSchemaLocation(Element, XmlConfigurationCallback, Map<String, String>) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
addSchemaRedirect(String, String) - Method in class org.mule.module.json.validation.JsonSchemaValidator.Builder
Allows to redirect any given URI in the Schema (or even the schema location itself) to any other specific URI.
addSchemaRedirects(Map<String, String>) - Method in class org.mule.module.json.validation.JsonSchemaValidator.Builder
Allows adding many redirects following the same rules as JsonSchemaValidator.Builder.addSchemaRedirect(String, String)
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(ShutdownListener) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
addShutdownListener(ShutdownListener) - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
addShutdownListener(ShutdownListener) - Method in interface org.mule.module.launcher.artifact.ArtifactClassLoader
Adds a shutdown listener to the class loader.
addSource(MessageSource) - Method in interface org.mule.api.source.CompositeMessageSource
 
addSource(MessageSource) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
addSource(MessageSource) - Method in class org.mule.source.StartableCompositeMessageSource
 
addStartupListener(StartupListener) - Method in interface org.mule.module.launcher.DeploymentService
 
addStartupListener(StartupListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
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
 
addTransportCustomizer(TransportCustomizer) - Method in class org.mule.module.http.internal.request.grizzly.CompositeTransportCustomizer
 
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<URL>) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
Setter for property 'urls'.
addUrls() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
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
 
addWildcardRequestHandler(HttpListenerRegistry.RequestHandlerMatcherPair) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
addWork(Runnable) - Method in class org.mule.transport.ConcurrentWorkTracker
 
addWork(Runnable) - Method in interface org.mule.transport.WorkTracker
Adds a work for tracking.
addZippedPlugin(File) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Adds a plugin file to the Mule server.
addZippedPlugin(URL) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Adds a plugin to the Mule server .
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
 
after() - Method in class org.mule.test.infrastructure.process.rules.MuleInstallation
 
after() - Method in class org.mule.test.infrastructure.process.rules.MuleStandalone
 
afterExecute(Object, Method, Object[]) - Method in interface org.mule.util.Multicaster.InvokeListener
 
afterFailureProcessingFlow(Exception) - Method in interface org.mule.execution.AsyncResponseFlowProcessingPhaseTemplate
Call when the processing of the message through the flow fails in an exception strategy
afterFailureProcessingFlow(MessagingException) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Call when the processing of the message through the flow fails.
afterFailureProcessingFlow(MuleException) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Call when the processing of the message through the flow fails in an exception strategy
afterFailureProcessingFlow(Exception) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
afterFailureProcessingFlow(MessagingException) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
afterFailureProcessingFlow(MuleException) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
afterFailureProcessingFlow(MuleException) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
afterFailureProcessingFlow(MuleException) - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
afterLifecycle(LifecyclePhase, Object) - Method in interface org.mule.api.lifecycle.LifecycleInterceptor
Invoked after the given phase was applied over the object.
afterLifecycle(LifecyclePhase, Object) - Method in class org.mule.lifecycle.InitDisposeLifecycleInterceptor
If the phase name is Initialisable.PHASE_NAME then it tracks the given object as initialised.
afterLifecycle(LifecyclePhase, Object) - Method in class org.mule.lifecycle.NullLifecycleInterceptor
NoOp implementation
afterPropertiesSet() - Method in class org.mule.config.spring.util.SystemPropertyInitializingBean
Sets the system properties
afterRouteEvent(MuleEvent) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Post processing of the routed MuleEvent
afterRouteEvent(MuleEvent) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
afterRouting(Exception, MuleEvent) - Method in class org.mule.exception.CatchMessagingExceptionStrategy
 
afterRouting(Exception, MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
afterSuccessfulProcessingFlow(MuleEvent) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Call after successfully processing the message through the flow This method will always be called when the flow execution was successful.
afterSuccessfulProcessingFlow(MuleEvent) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
AGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
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
Deprecated.
 
agentsRunning() - Static method in class org.mule.config.i18n.CoreMessages
 
aggregate(AggregationContext) - Method in class org.mule.config.spring.factories.AggregationStrategyDefinitionParser.AggregationStrategyDelegate
 
aggregate(AggregationContext) - Method in interface org.mule.routing.AggregationStrategy
aggregates the events in the given context into a single one
aggregate(AggregationContext) - Method in class org.mule.routing.CollectAllAggregationStrategy
 
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) - 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
Aggregates the events in the results list into one single MuleEvent You should only use this method when you're sure that all the events in the results list were generated by the same thread that's going to handle the aggregated response
aggregateWithFailedRoutes(AggregationContext) - Method in class org.mule.routing.CollectAllAggregationStrategy
 
aggregateWithoutFailedRoutes(AggregationContext) - Method in class org.mule.routing.CollectAllAggregationStrategy
 
AggregationContext - Class in org.mule.api.routing
Immutable object used to provide all the necessary information to perform an aggregation operation in one single parameter, helping to maintain consistent and simple signatures across aggregators The most important attribute in this class is AggregationContext.events which holds the events to be aggregated.
AggregationContext(MuleEvent, List<MuleEvent>) - Constructor for class org.mule.api.routing.AggregationContext
Creates a new instance
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
 
AggregationStrategy - Interface in org.mule.routing
Strategy pattern for aggregating a list of MuleEvent passed through a AggregationContext into a single one
AggregationStrategyDefinitionParser - Class in org.mule.config.spring.factories
 
AggregationStrategyDefinitionParser() - Constructor for class org.mule.config.spring.factories.AggregationStrategyDefinitionParser
 
AggregationStrategyDefinitionParser.AggregationStrategyDelegate - Class in org.mule.config.spring.factories
 
AggregationStrategyDefinitionParser.AggregationStrategyDelegate() - Constructor for class org.mule.config.spring.factories.AggregationStrategyDefinitionParser.AggregationStrategyDelegate
 
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
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() - 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, MuleContext) - 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(List<NestedProcessor>, MuleEvent) - Method in class org.mule.extension.validation.internal.ValidationStrategies
Perform a list of nested validation operations and informs only one MultipleValidationResult which summarizes all of the found errors (if any).
All - Class in org.mule.module.extension.internal.capability.xml.schema.model
Only elements allowed inside

All() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.All
 
all - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ComplexType
 
all - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ExtensionType
 
all - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.RestrictionType
 
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_INTERFACES_IP - Static variable in class org.mule.module.http.api.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
 
allElements() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
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.PersistentObjectStorePartition
 
allKeys() - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
allKeys(String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
allKeys() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
allKeys() - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
allKeys() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
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
 
ALLOW - Static variable in class org.mule.module.http.api.HttpHeaders.Names
allowAliasOverriding() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Only allows alias overriding if bean definition overriding is allowed.
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
 
allPartitions() - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
allPollSchedulers() - Static method in class org.mule.api.schedule.Schedulers
 
AllStatistics - Class in org.mule.management.stats
AllStatistics TODO
AllStatistics() - Constructor for class org.mule.management.stats.AllStatistics
 
alphaSortDescribedList(List<T>) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
Sorts the given list in ascending alphabetic order, using Described.getName() as the sorting criteria
ANCHOR_FILE_BLURB - Static variable in class org.mule.module.launcher.ArtifactArchiveInstaller
 
ANCHOR_SUFFIX - Static variable in class org.mule.test.infrastructure.process.Controller
 
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
 
Annotated - Class in org.mule.module.extension.internal.capability.xml.schema.model
This type is extended by all types which allow annotation other than itself

Annotated() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.Annotated
 
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
 
AnnotatedObjectFactoryBean<B extends AnnotatedObject> - Class in org.mule.config.spring.factories
Extends spring's AbstractFactoryBean by adding annotations.
AnnotatedObjectFactoryBean() - Constructor for class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
AnnotatedService - Annotation Type in org.mule.module.guice
Deprecated.
AnnotatedTransformerObjectPostProcessor - Class in org.mule.config.spring.processors
Will check all method level annotations to see if there are any Transformer annotations present.
AnnotatedTransformerObjectPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.processors.AnnotatedTransformerObjectPostProcessor
 
AnnotatedTransformerObjectProcessor - Class in org.mule.config.transformer
Deprecated.
as of 3.7.0 since these are only used by TransientRegistry which is also deprecated. Use post processors for currently supported registries instead (i.e: SpringRegistry)
AnnotatedTransformerObjectProcessor() - Constructor for class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
Deprecated.
 
AnnotatedTransformerObjectProcessor(MuleContext) - Constructor for class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
Deprecated.
 
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
 
annotation - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Annotated
 
Annotation - Class in org.mule.module.extension.internal.capability.xml.schema.model
Java class for anonymous complex type.
Annotation() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.Annotation
 
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
Deprecated.
AnnotationInfo - Class in org.mule.util.scan.annotations
Deprecated.
AnnotationInfo() - Constructor for class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
AnnotationInfo.NameValue - Class in org.mule.util.scan.annotations
Deprecated.
 
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
 
annotationOrSimpleTypeOrComplexType - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Redefine
 
AnnotationProcessorUtils - Class in org.mule.module.extension.internal.capability.xml.schema
Utility class for annotation processing using the Processor API
annotations - Variable in class org.mule.transport.polling.watermark.Watermark
The watermark annotations added to the definition
ANNOTATIONS_PACKAGE_NAME - Static variable in class org.mule.module.json.transformers.JsonMapperResolver
 
AnnotationsBasedDescriber - Class in org.mule.module.extension.internal.introspection
Implementation of Describer which generates a Descriptor by scanning annotations on a type provided in the constructor
AnnotationsBasedDescriber(Class<?>) - Constructor for class org.mule.module.extension.internal.introspection.AnnotationsBasedDescriber
 
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
Deprecated.
AnnotationsScanner() - Constructor for class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
AnnotationsScanner(AnnotationFilter) - Constructor for class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
AnnotationTypeFilter - Class in org.mule.util.scan.annotations
Deprecated.
AnnotationTypeFilter(Class<? extends Annotation>) - Constructor for class org.mule.util.scan.annotations.AnnotationTypeFilter
Deprecated.
 
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.DefaultArchiveDeployer
 
ANT_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
ANT_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
Any - Class in org.mule.module.extension.internal.capability.xml.schema.model
Java class for anonymous complex type.
Any() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.Any
 
ANY - Static variable in interface org.mule.transformer.types.MimeTypes
 
ANY_MIME_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
ANY_PATH - Static variable in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
anyAttribute - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.AttributeGroup
 
anyAttribute - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ComplexType
 
anyAttribute - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ExtensionType
 
anyAttribute - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.RestrictionType
 
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.util.XMLUtils
 
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
 
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
 
AppDeploymentProbe - Class in org.mule.test.infrastructure.process
 
AppDeploymentProbe(MuleProcessController, String, Boolean) - Constructor for class org.mule.test.infrastructure.process.AppDeploymentProbe
 
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(LogEvent) - Method in class org.mule.tck.logging.TestAppender
 
append(String, String) - Static method in class org.mule.transformer.simple.StringAppendTransformer
 
append2digits(StringBuilder, int) - Static method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
appendAction(Map<String, Object>, String) - Method in class org.mule.module.ws.security.AbstractSecurityStrategy
Adds an action to a CXF config map.
appendDefault(String) - Static method in class org.mule.tck.functional.StringAppendTestTransformer
 
appendElementBody(String) - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
Adds the body of the xml tag.
appendElementBody(String) - Method in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
Adds the body of the xml tag.
appendElementEnd(String) - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
Builds the closing tag of the xml element.
appendElementEnd(String) - Method in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
Builds the closing tag of the xml element.
appendElementStart(String, Map<String, String>) - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
Builds the opening tag of the xml element.
appendElementStart(String, Map<String, String>) - Method in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
Builds the opening tag of the xml element.
appendJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
 
appendMessage(String) - Method in exception org.mule.api.MuleException
 
appendQueryParam(String, String, String) - Static method in class org.mule.module.http.internal.HttpParser
Appends a query parameter to an URL that may or may not contain query parameters already.
Appinfo - Class in org.mule.module.extension.internal.capability.xml.schema.model
Java class for anonymous complex type.
Appinfo() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.Appinfo
 
appinfoOrDocumentation - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Annotation
 
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_JSON - Static variable in interface org.mule.transformer.types.MimeTypes
 
APPLICATION_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
APPLICATION_STARTED_TIMEOUT_IN_SECONDS - Static variable in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
APPLICATION_X_WWW_FORM_URLENCODED - Static variable in class org.mule.module.http.api.HttpHeaders.Values
APPLICATION_XML - Static variable in interface org.mule.transformer.types.MimeTypes
 
ApplicationClassLoader - Interface in org.mule.module.launcher.application
Identifies a classLoader created for a given Mule application
ApplicationClassLoaderFactory - Interface in org.mule.module.launcher.application
Creates ClassLoader instances for Mule applications
applicationClassLoaderFactory - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
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.config.spring.SpringXmlConfigurationBuilder
 
applicationContext - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
The Spring application context
ApplicationContextBuilder - Class in org.mule.tck.junit4
 
ApplicationContextBuilder() - Constructor for class org.mule.tck.junit4.ApplicationContextBuilder
 
ApplicationCredentials - Interface in org.mule.module.oauth2.internal
OAuth app client credentials
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
Deprecated.
ApplicationEventException(String) - Constructor for exception org.mule.module.spring.events.ApplicationEventException
Deprecated.
 
ApplicationEventException(String, Throwable) - Constructor for exception org.mule.module.spring.events.ApplicationEventException
Deprecated.
 
ApplicationFactory - Interface in org.mule.module.launcher.application
Creates Application instances
ApplicationMuleContextBuilder - Class in org.mule.module.launcher.application
Takes Mule application descriptor into account when building the context.
ApplicationMuleContextBuilder(ApplicationDescriptor) - Constructor for class org.mule.module.launcher.application.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
 
ApplicationStartedDeploymentListener - Class in org.mule.test.infrastructure.process
 
ApplicationStartedDeploymentListener() - Constructor for class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
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
 
ApplicationStatus - Enum in org.mule.module.launcher.application
Indicates the status of a Mule application that corresponds to the last executed lifecycle phase on the application's MuleContext.
ApplicationStatusMapper - Class in org.mule.module.launcher.application
Maps an application life cycle phase to an application status
ApplicationStatusMapper() - Constructor for class org.mule.module.launcher.application.ApplicationStatusMapper
 
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
 
appliesTo(DataSource, MuleContext) - Method in class org.mule.module.db.internal.domain.xa.CompositeDataSourceDecorator
 
appliesTo(DataSource, MuleContext) - Method in interface org.mule.module.db.internal.domain.xa.DataSourceDecorator
Indicates whether or not this decorator can decorate a given datasource
appliesTo(DataSource, MuleContext) - Method in class org.mule.module.db.internal.domain.xa.DefaultDataSourceDecorator
 
appliesTo(DataSource, MuleContext) - Method in class org.mule.transport.jdbc.xa.CompositeDataSourceDecorator
 
appliesTo(DataSource, MuleContext) - Method in interface org.mule.transport.jdbc.xa.DataSourceDecorator
 
appliesTo(DataSource, MuleContext) - Method in class org.mule.transport.jdbc.xa.DefaultDataSourceDecorator
 
appliesTo(ConnectionFactory, MuleContext) - Method in class org.mule.transport.jms.CachingConnectionFactoryDecorator
 
appliesTo(ConnectionFactory, MuleContext) - Method in class org.mule.transport.jms.CompositeConnectionFactoryDecorator
 
appliesTo(ConnectionFactory, MuleContext) - Method in interface org.mule.transport.jms.ConnectionFactoryDecorator
 
appliesTo(ConnectionFactory, MuleContext) - Method in class org.mule.transport.jms.DefaultConnectionFactoryDecorator
 
apply(Map<String, Object>, Map<String, Object>) - Method in interface org.mule.module.ws.security.SecurityStrategy
Applies this security strategy to inbound and outbound configuration maps.
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssDecryptSecurityStrategy
 
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssSignSecurityStrategy
 
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
apply(Map<String, Object>, Map<String, Object>) - Method in class org.mule.module.ws.security.WssVerifySignatureSecurityStrategy
 
APPLY_TO_ARTIFACT_TYPE_PARAMETER_KEY - Static variable in enum org.mule.config.bootstrap.ArtifactType
 
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
 
applyDispatcherLifecycle(MessageDispatcher) - Method in class org.mule.transport.http.HttpConnector
 
applyDispatcherLifecycle(MessageDispatcher) - Method in class org.mule.transport.jdbc.JdbcConnector
 
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.LifecycleRegistry
Will fire any lifecycle methods according to the current lifecycle without actually registering the object in the registry.
applyLifecycle(Object, String) - Method in interface org.mule.api.registry.LifecycleRegistry
Will fire the given lifecycle phase without actually registering the object in the registry.
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(Object) - Method in class org.mule.config.spring.SpringRegistry
Will fire any lifecycle methods according to the current lifecycle without actually registering the object in the registry.
applyLifecycle(Object, String) - Method in class org.mule.config.spring.SpringRegistry
 
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 fire any lifecycle methods according to the current lifecycle without actually registering the object in the registry.
applyLifecycle(Object, String) - Method in class org.mule.registry.MuleRegistryHelper
Will fire the given lifecycle phase without actually registering the object in the registry.
applyLifecycle(Object) - Method in class org.mule.registry.SimpleRegistry
 
applyLifecycle(Object, String) - Method in class org.mule.registry.SimpleRegistry
 
applyLifecycle(MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
applyLifecycle(MessageRequester, boolean) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
applyLifecycle(MessageDispatcher) - Static method in class org.mule.transport.MessageDispatcherUtils
Applies lifecycle to a MessageDispatcher based on the lifecycle state of its connector.
applyLifecycleAndDependencyInjection(Object) - Method in class org.mule.component.AbstractComponent
 
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
Deprecated.
as of 3.7.0. Use MuleRegistry.applyProcessors(Object) instead.
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
Deprecated.
applyProcessors(Object, Object) - Method in class org.mule.registry.SimpleRegistry
 
applyProcessors(Map<String, Object>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
applyProcessors(Object, Object) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
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
 
APPS_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
appsDir - Variable in class org.mule.test.infrastructure.process.Controller
 
ArchiveDeployer<T extends Artifact> - Interface in org.mule.module.launcher
Deploys a file based artifact into the mule container.
ArgumentResolver<T> - Interface in org.mule.module.extension.internal.runtime.resolver
A component for resolving the value of an operation's argument
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
 
ARRAY_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
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
 
arrayIsEmpty() - Method in class org.mule.extension.validation.internal.ValidationMessages
Generates a Message for an array which was expected to be not empty but was
arrayIsNotEmpty() - Method in class org.mule.extension.validation.internal.ValidationMessages
Generates a Message for an array which was expected to be empty but wasn't
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
 
Artifact<D extends ArtifactDescriptor> - Interface in org.mule.module.launcher.artifact
An Artifact is an abstract representation of a deployable unit within the mule container.
ARTIFACT_ANCHOR_SUFFIX - Static variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
ARTIFACT_ANCHOR_SUFFIX - Static variable in class org.mule.module.launcher.MuleDeploymentService
 
ARTIFACT_NAME_PROPERTY - Static variable in class org.mule.module.launcher.DefaultArchiveDeployer
 
ArtifactArchiveInstaller - Class in org.mule.module.launcher
Installer for mule artifacts inside the mule container directories.
ArtifactArchiveInstaller(File) - Constructor for class org.mule.module.launcher.ArtifactArchiveInstaller
 
ArtifactClassLoader - Interface in org.mule.module.launcher.artifact
 
ArtifactDeployer<T extends Artifact> - Interface in org.mule.module.launcher
Deployes and Undeploys artifacts in the container.
ArtifactDeployerMonitorThreadFactory - Class in org.mule.module.launcher
 
ArtifactDeployerMonitorThreadFactory() - Constructor for class org.mule.module.launcher.ArtifactDeployerMonitorThreadFactory
 
ArtifactDeploymentStatusTracker - Class in org.mule.module.launcher
Keeps track of the deployment status of the artifact listening to the deployment notifications
ArtifactDeploymentStatusTracker() - Constructor for class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
ArtifactDeploymentStatusTracker.DeploymentState - Enum in org.mule.module.launcher
 
ArtifactDeploymentTemplate - Interface in org.mule.module.launcher
Utility to hook callbacks just before and after an artifact is redeployed in Mule.
ArtifactDescriptor - Class in org.mule.module.launcher.descriptor
Represents a base description of an Artifact
ArtifactDescriptor() - Constructor for class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
ArtifactFactory<T extends Artifact> - Interface in org.mule.module.launcher.artifact
Generic Factory for an Artifact.
ArtifactFactoryUtils - Class in org.mule.module.launcher.artifact
Utility class providing useful methods when creating Artifacts.
ArtifactType - Enum in org.mule.config.bootstrap
List the possible types of deployable artifacts
ArtifactWrapper<T extends Artifact<D>,D extends ArtifactDescriptor> - Class in org.mule.module.launcher.artifact
Decorates the target deployer to properly switch out context classloader for deployment one where applicable.
ArtifactWrapper(T) - Constructor for class org.mule.module.launcher.artifact.ArtifactWrapper
 
asArrayOfCookies(Object) - Static method in class org.mule.transport.http.CookieHelper
Returns an array view of the cookiesObject.
asHashMap() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
Returns a copy of this map which is case insensitive but doesn't have the copy-on-write functionality.
asJsonNode(Object) - Method in class org.mule.module.json.DefaultJsonParser
Parses the given input into a JsonNode.
asJsonNode(Object) - Method in interface org.mule.module.json.JsonParser
Parses the given input into a JsonNode.
asMap() - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
 
asOperationContextAdapter(OperationContext) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
 
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
 
assertDeploymentFailure(String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
assertDeploymentSuccess(String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
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
 
assertExpectedException(Class<? extends Throwable>) - Method in class org.mule.tck.listener.ExceptionListener
 
assertExpectedExceptionCausedBy(Class<? extends Throwable>) - Method in class org.mule.tck.listener.ExceptionListener
Asserts that there is at least one exception with the given cause
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
 
assertFileExists(File, String) - Static method in class org.mule.test.infrastructure.deployment.DeploymentTestUtils
 
AssertionMessageProcessor - Class in org.mule.tck.functional
 
AssertionMessageProcessor() - Constructor for class org.mule.tck.functional.AssertionMessageProcessor
 
assertMinimumTimeBetweenNotifications(long) - Method in class org.mule.tck.listener.ConnectionListener
 
assertMuleParent(Element) - Method in class org.mule.config.spring.parsers.generic.MuleOrphanDefinitionParser
 
assertNonConsumableMessage(MuleEvent, MuleMessage) - Static method in class org.mule.routing.AbstractRoutingStrategy
Asserts that the MuleMessage in the MuleEvent doesn't carry a consumable payload.
assertNotOpen() - Method in class org.apache.commons.httpclient.HttpConnection
Throws an IllegalStateException if the connection is already open.
assertNotUsed() - Method in class org.mule.endpoint.URIBuilder
 
assertOpen() - Method in class org.apache.commons.httpclient.HttpConnection
Throws an IllegalStateException if the connection is not open.
assertProtocolConsistent() - Method in class org.mule.endpoint.URIBuilder
 
assertStackElements(FlowCallStack, Matcher<FlowStackElement>...) - Static method in class org.mule.tck.util.FlowTraceUtils
 
assertTargetPresent() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
assertUndeploymentSuccess(String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
assertUndeploymentSuccess(DeploymentListener, String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
assignValue(String, T, T) - Method in interface org.mule.api.el.VariableAssignmentCallback
 
asString() - Method in enum org.mule.module.http.internal.domain.HttpProtocol
 
assureReady() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Check that the FileManager is ready.
assureReady() - Method in class org.mule.util.xa.AbstractResourceManager
Check that the FileManager is ready.
assureStarted() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Check that the FileManager is started.
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_MESSAGE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
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
Deprecated.
Determines whether events will be processed asynchronously
AsynchronousEventListener - Class in org.mule.module.spring.events
Deprecated.
AsynchronousEventListener(ExecutorService, ApplicationListener) - Constructor for class org.mule.module.spring.events.AsynchronousEventListener
Deprecated.
 
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
 
AsynchronousUntilSuccessfulProcessingStrategy - Class in org.mule.routing
Until successful asynchronous processing strategy.
AsynchronousUntilSuccessfulProcessingStrategy() - Constructor for class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
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
 
AsyncLoggerExceptionHandler - Class in org.mule.module.launcher.log4j2
Implementation of ExceptionHandler to be used when async loggers fail to log their messages.
AsyncLoggerExceptionHandler() - Constructor for class org.mule.module.launcher.log4j2.AsyncLoggerExceptionHandler
 
AsyncMessageNotification - Class in org.mule.context.notification
AsyncMessageNotification when async work is scheduled and completed for a given flow
AsyncMessageNotification(FlowConstruct, MuleEvent, MessageProcessor, int) - Constructor for class org.mule.context.notification.AsyncMessageNotification
 
AsyncMessageNotification(FlowConstruct, MuleEvent, MessageProcessor, int, MessagingException) - Constructor for class org.mule.context.notification.AsyncMessageNotification
 
AsyncMessageNotificationListener<T extends AsyncMessageNotification> - Interface in org.mule.api.context.notification
 
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
Deprecated.
An ExecutorService for handling asynchronous events
asyncReceiveRemote(String, int) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
asyncReplyMessageSource - Variable in class org.mule.service.AbstractService
Deprecated.
 
AsyncReplyToPropertyRequestReplyReplier - Class in org.mule.routing.requestreply
 
AsyncReplyToPropertyRequestReplyReplier() - Constructor for class org.mule.routing.requestreply.AsyncReplyToPropertyRequestReplyReplier
 
AsyncResponseFlowProcessingPhase - Class in org.mule.execution
This phase routes the message through the flow.
AsyncResponseFlowProcessingPhase() - Constructor for class org.mule.execution.AsyncResponseFlowProcessingPhase
 
AsyncResponseFlowProcessingPhaseTemplate - Interface in org.mule.execution
Template methods for MessageSource specific behavior during flow execution.
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
 
attachProcessorDefinition(ParserContext, BeanDefinition) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
attachSourceDefinition(ParserContext, BeanDefinition) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
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 in org.mule.module.extension.internal.capability.xml.schema.model
Java class for attribute complex type.
Attribute() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.Attribute
 
ATTRIBUTE_CLASS - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_DESCRIPTION_CONFIG - Static variable in class org.mule.module.extension.internal.capability.xml.schema.model.SchemaConstants
 
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_NAME_CONFIG - Static variable in class org.mule.module.extension.internal.capability.xml.schema.model.SchemaConstants
 
ATTRIBUTE_NAME_NAME - Static variable in class org.mule.module.extension.internal.capability.xml.schema.model.SchemaConstants
 
ATTRIBUTE_NAME_NAME_DESCRIPTION - Static variable in class org.mule.module.extension.internal.capability.xml.schema.model.SchemaConstants
 
ATTRIBUTE_NAME_VALUE - Static variable in class org.mule.module.extension.internal.capability.xml.schema.model.SchemaConstants
 
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
 
attributeFormDefault - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Schema
 
AttributeGroup - Class in org.mule.module.extension.internal.capability.xml.schema.model
Java class for attributeGroup complex type.
AttributeGroup() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.AttributeGroup
 
AttributeGroupRef - Class in org.mule.module.extension.internal.capability.xml.schema.model
Java class for attributeGroupRef complex type.
AttributeGroupRef() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.AttributeGroupRef
 
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.
attributeOrAttributeGroup - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.AttributeGroup
 
attributeOrAttributeGroup - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ComplexType
 
attributeOrAttributeGroup - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ExtensionType
 
attributeOrAttributeGroup - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.RestrictionType
 
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
 
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, HttpRequestBuilder) - Method in interface org.mule.module.http.api.HttpAuthentication
Adds authentication information to the request.
authenticate(MuleEvent, HttpRequestBuilder) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
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(MuleEvent, HttpRequestBuilder) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
authenticate(MuleEvent, HttpRequestBuilder) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
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
 
authenticate(HttpServletResponse) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
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.
AuthenticationMethodValidator - Class in org.mule.transport.sftp
Validates SFTP authentication methods
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
 
AUTHORIZATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
AUTHORIZATION_EVENT_KEY_TEMPLATE - Static variable in interface org.mule.security.oauth.OAuthProperties
 
AUTHORIZATION_STATUS_QUERY_PARAM_KEY - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
AUTHORIZATION_URL - Static variable in class org.mule.security.oauth.BaseOAuth2Manager
 
authorizationAttemptFailed() - Static method in class org.mule.config.i18n.CoreMessages
 
AuthorizationCodeGrantType - Interface in org.mule.module.oauth2.internal.authorizationcode
Provides access to the general configuration of an authorization code oauth config.
AuthorizationCodeNotFoundException - Exception in org.mule.security.oauth.exception
Exception to signal that an OAuth http callback was received but an authorization code could not be found on it.
AuthorizationCodeNotFoundException(Pattern, String) - Constructor for exception org.mule.security.oauth.exception.AuthorizationCodeNotFoundException
Creates a new instance
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
 
AuthorizationRequestHandler - Class in org.mule.module.oauth2.internal.authorizationcode
Handles the call to the localAuthorizationUrl and redirects the user to the oauth authentication server authorization url so the user can grant access to the resources to the mule application.
AuthorizationRequestHandler() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
AuthorizationRequestUrlBuilder - Class in org.mule.module.oauth2.internal.authorizationcode
Builds the authorization url to redirect the user to.
AuthorizationRequestUrlBuilder() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
authorize(Map<String, String>, String, String, String, String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Builds the authorization url to initiate the OAuth dance
authorize(Map<String, String>, String, String) - Method in interface org.mule.security.oauth.OAuth2Adapter
Build authorization URL and create the inbound endpoint for the callback
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
 
AUTO_GENERATED_KEY_STRATEGY_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
AUTO_GENERATED_KEYS_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
AutoAuthorizationCodeTokenRequestHandler - Class in org.mule.module.oauth2.internal.authorizationcode
Represents the Token request and response handling behaviour of the OAuth 2.0 dance.
AutoAuthorizationCodeTokenRequestHandler() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
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
 
AutoGeneratedKeysProcessingException - Exception in org.mule.module.db.internal.result.statement
Thrown to indicate an error during auto generated keys processing
AutoGeneratedKeysProcessingException(Throwable) - Constructor for exception org.mule.module.db.internal.result.statement.AutoGeneratedKeysProcessingException
 
autoGeneratedKeyStrategy - Variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
AutoGeneratedKeyStrategy - Interface in org.mule.module.db.internal.domain.autogeneratedkey
Manages different ways to process auto generated keys
autoGeneratedKeyStrategy - Variable in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
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
 
awaitTermination() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
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() - 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

BackwardsCompatibilityPropertyChecker - Class in org.mule.util
Class to check that system properties introduced to maintain backwards compatibility are enabled or not, the latter being the default.
BackwardsCompatibilityPropertyChecker(String) - Constructor for class org.mule.util.BackwardsCompatibilityPropertyChecker
 
base - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ExtensionType
 
base - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Restriction
 
base - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.RestrictionType
 
BASE64 - Static variable in class org.mule.module.http.api.HttpHeaders.Values
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
 
BaseConnectorMessageNotification - Class in org.mule.context.notification
These notifications are fired when either a message is received from or dispatched to an external entity.
BaseConnectorMessageNotification(MuleMessage, String, FlowConstruct, int) - Constructor for class org.mule.context.notification.BaseConnectorMessageNotification
 
BaseOAuth1AuthorizeMessageProcessor - Class in org.mule.security.oauth.processor
 
BaseOAuth1AuthorizeMessageProcessor() - Constructor for class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
 
BaseOAuth1Manager - Class in org.mule.security.oauth
 
BaseOAuth1Manager() - Constructor for class org.mule.security.oauth.BaseOAuth1Manager
 
BaseOAuth1UnauthorizeMessageProcessor - Class in org.mule.security.oauth.processor
 
BaseOAuth1UnauthorizeMessageProcessor() - Constructor for class org.mule.security.oauth.processor.BaseOAuth1UnauthorizeMessageProcessor
 
BaseOAuth2AuthorizeMessageProcessor<T extends OAuth2Manager<OAuth2Adapter>> - Class in org.mule.security.oauth.processor
 
BaseOAuth2AuthorizeMessageProcessor() - Constructor for class org.mule.security.oauth.processor.BaseOAuth2AuthorizeMessageProcessor
 
BaseOAuth2Manager<C extends OAuth2Adapter> - Class in org.mule.security.oauth
 
BaseOAuth2Manager() - Constructor for class org.mule.security.oauth.BaseOAuth2Manager
 
BaseOAuth2UnauthorizeMessageProcessor<T extends OAuth2Manager<OAuth2Adapter>> - Class in org.mule.security.oauth.processor
 
BaseOAuth2UnauthorizeMessageProcessor() - Constructor for class org.mule.security.oauth.processor.BaseOAuth2UnauthorizeMessageProcessor
 
BaseOAuthClientFactory - Class in org.mule.security.oauth
 
BaseOAuthClientFactory(OAuth2Manager<OAuth2Adapter>, ObjectStore<Serializable>) - Constructor for class org.mule.security.oauth.BaseOAuthClientFactory
 
basepath - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
BaseResponseCompletionHandler - Class in org.mule.module.http.internal.listener.grizzly
 
BaseResponseCompletionHandler() - Constructor for class org.mule.module.http.internal.listener.grizzly.BaseResponseCompletionHandler
 
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
 
BasicAuthenticationBuilder - Class in org.mule.module.http.api.requester.authentication
Builder for HTTP basic authentication credentials
BasicAuthenticationBuilder(MuleContext) - Constructor for class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
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
Deprecated.
This expression evaluator is deprecated and will be removed in Mule 4.0. Use MEL expressions instead
BeanPayloadExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
beanPropertyConfiguration - Variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
BEANS - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
BEANS_ELEMENT - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
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
 
before() - Method in class org.mule.test.infrastructure.process.rules.MuleInstallation
 
before() - Method in class org.mule.test.infrastructure.process.rules.MuleStandalone
 
beforeLifecycle(LifecyclePhase, Object) - Method in interface org.mule.api.lifecycle.LifecycleInterceptor
Invoked before the given phase is applied over the object.
beforeLifecycle(LifecyclePhase, Object) - Method in class org.mule.lifecycle.InitDisposeLifecycleInterceptor
Evaluates the following conditions in order to determine if the phase should be skipped:
beforeLifecycle(LifecyclePhase, Object) - Method in class org.mule.lifecycle.NullLifecycleInterceptor
 
beforeRouteEvent(MuleEvent) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Pre processing of the MuleEvent to route
beforeRouteEvent(MuleEvent) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
beforeRouteEvent(MuleEvent) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
beforeRouteEvent(MuleEvent) - Method in class org.mule.transport.http.HttpsMessageProcessTemplate
 
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 class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
begin() - Method in interface org.mule.util.queue.QueueSession
Starts a transaction to execute operations over a set of queue with atomicity.
begin() - Method in class org.mule.util.queue.TransactionalQueueSession
 
beginTransaction(MuleContext) - Method in interface org.mule.api.transaction.TransactionFactory
Create and begins a new transaction
beginTransaction(MuleContext) - Method in class org.mule.module.db.internal.domain.transaction.DbTransactionFactory
 
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.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
beginTransaction(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
belongs(int) - Method in class org.mule.module.http.internal.request.RangeStatusCodeValidator
 
bestGuessName(PropertyConfiguration, String, String) - Static method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
BIGINT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
BINARY - Static variable in class org.mule.module.http.api.HttpHeaders.Values
BINARY - Static variable in interface org.mule.transformer.types.MimeTypes
 
BINARY_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
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
 
BIND_TO_ALL_INTERFACES_IP - Static variable in class org.mule.transport.http.HttpConnector
 
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.db.internal.domain.transaction.DbTransaction
 
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
 
BIT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
blackList(String) - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
blankAttribute(Element, String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
BLOB_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
block - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ComplexType
 
block - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Element
 
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
 
blockDefault - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.Schema
 
blocked - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
BlockingProcessorExecutor - Class in org.mule.processor
This ProcessorExecutor implementation executes each MessageProcessor in sucession in the same thread until or processors have been invoked or one of the following is returned by a processor: VoidMuleEvent null
BlockingProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Constructor for class org.mule.processor.BlockingProcessorExecutor
 
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
BlockingTransferInputStream - Class in org.mule.module.http.internal.listener.grizzly
InputStream to be used when the HTTP request has Transfer-Encoding: chunked or the content is not fully provided because the message is too large.
BlockingTransferInputStream(FilterChainContext, InputStream) - Constructor for class org.mule.module.http.internal.listener.grizzly.BlockingTransferInputStream
 
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
 
BOOLEAN_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
BooleanAttributeSelectionDefinitionParser - Class in org.mule.config.spring.parsers.delegate
 
BooleanAttributeSelectionDefinitionParser(String, boolean, MuleDefinitionParser, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.BooleanAttributeSelectionDefinitionParser
 
BooleanValidator - Class in org.mule.extension.validation.internal.validator
An AbstractValidator which tests a BooleanValidator.value to match a BooleanValidator.expected one
BooleanValidator(boolean, boolean, ValidationContext) - Constructor for class org.mule.extension.validation.internal.validator.BooleanValidator
 
BootstrapException - Exception in org.mule.config.bootstrap
Represents exceptions during the bootstrap configuration process
BootstrapException(Message, Throwable) - Constructor for exception org.mule.config.bootstrap.BootstrapException
 
BootstrapException(Message) - Constructor for exception org.mule.config.bootstrap.BootstrapException
 
BootstrapObjectFactory - Interface in org.mule.config.bootstrap
A simple factory interface that can be listed in a registry-bootstrap.properties file
BootstrapObjectFactoryBean - Class in org.mule.config.spring.factories
A which returns an object created through a {@link BootstrapObjectFactory}
BootstrapObjectFactoryBean(BootstrapObjectFactory) - Constructor for class org.mule.config.spring.factories.BootstrapObjectFactoryBean
 
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
 
borrowDispatcher(OutboundEndpoint) - Method in class org.mule.transport.AbstractConnector
 
borrowDispatcher(OutboundEndpoint) - Method in class org.mule.transport.http.HttpConnector
 
borrowDispatcher(OutboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
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
 
BOUNDARY - Static variable in class org.mule.module.http.api.HttpHeaders.Values
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
Breakpoint - Class in org.mule.api.debug
Identifies an execution breakpoint.
Breakpoint(String, String) - Constructor for class org.mule.api.debug.Breakpoint
It contains the location of where the execution needs to stop and the condition if any.
BreakpointManager - Interface in org.mule.api.debug
Manages the breakpoint in the debugging session.
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
 
bufferSize - Static variable in class org.mule.util.IOUtils
 
build() - Method in class org.mule.api.client.AbstractBaseOptionsBuilder
 
build() - Method in class org.mule.api.client.SimpleOptionsBuilder
 
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(MuleEvent) - Method in class org.mule.endpoint.DynamicURIBuilder
 
build() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
build() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
build - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.BuiltBy
 
build() - Method in class org.mule.module.extension.internal.capability.xml.schema.SchemaBuilder
 
build(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.ConfigurationObjectBuilder
 
build(ResolverSetResult) - Method in class org.mule.module.extension.internal.runtime.ConfigurationObjectBuilder
 
build(MuleEvent) - Method in interface org.mule.module.extension.internal.runtime.ObjectBuilder
Returns a new instance of the specified class.
build() - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult.Builder
Creates a new ResolverSetResult
build() - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
build() - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
build() - Method in class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
build() - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
Builder the request config and initializes it.
build() - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
build() - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
build() - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
build() - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
build() - Method in class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
build(HttpResponseBuilder, MuleEvent) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
build() - Method in class org.mule.module.http.internal.listener.HttpThrottlingHeadersMapBuilder
 
build() - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
build() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
build() - Method in class org.mule.module.json.validation.JsonSchemaValidator.Builder
Builds a new instance per the given configuration.
build(ClassLoader, ArtifactAwareContextSelector) - Method in class org.mule.module.launcher.log4j2.MuleLoggerContextFactory
Builds a new LoggerContext for the given classLoader and selector
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.
build() - Method in class org.mule.tck.junit4.ApplicationContextBuilder
 
build() - Method in class org.mule.tck.junit4.DomainContextBuilder
 
buildAndRegister(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
buildAuthorizationHeaderContent(String) - Static method in class org.mule.module.oauth2.internal.AbstractGrantType
 
buildAuthorizeUrl(OAuth1Adapter, Map<String, String>, String, String, String, String) - Method in class org.mule.security.oauth.BaseOAuth1Manager
Builds the authorization url to initiate the OAuth dance
buildAuthorizeUrl(Map<String, String>, String, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Generates the full URL of an authorization endpoint including query params
buildAuthorizeUrl(OAuth1Adapter, Map<String, String>, String, String, String, String) - Method in interface org.mule.security.oauth.OAuth1Manager
Builds the authorization url to initiate the OAuth dance
buildAuthorizeUrl(Map<String, String>, String, String) - Method in interface org.mule.security.oauth.OAuth2Manager
Generates the full URL of an authorization endpoint including query params
buildDefault() - Method in class org.mule.transport.ssl.api.TlsContextFactoryBuilder
 
Builder<T> - Interface in org.mule.config.dsl
Deprecated.
builder - Variable in class org.mule.module.db.internal.domain.logger.AbstractDebugQueryLogger
 
builder() - Static method in class org.mule.module.json.validation.JsonSchemaValidator
buildErrorResponse() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
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.OldHttpMessageReceiver.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.AbstractJmxAgent
 
buildHttpResponsePacket(HttpRequestPacket, HttpResponse) - Method in class org.mule.module.http.internal.listener.grizzly.BaseResponseCompletionHandler
 
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
 
buildInnerPaths() - Method in interface org.mule.processor.chain.DynamicMessageProcessorContainer
Builds the flowMap for the inner processors relative to the calling flow.
buildInstance(int) - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
buildMessageProcessorChain(DefaultMessageProcessorChain) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
buildMessageProcessorChain(DefaultMessageProcessorChain) - Method in class org.mule.processor.chain.SubflowMessageProcessorChainBuilder
 
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
 
buildPath(String, String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
buildPathResolver(MessageProcessorPathElement) - Static method in class org.mule.util.NotificationUtils
 
buildPaths(MessageProcessorPathElement) - Static method in class org.mule.util.NotificationUtils
buildProxy(ProxyConfig) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
buildQueueKey(MuleEvent) - Static method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
buildResponse(MuleEvent, HttpResponseBuilder, ResponseCompletionCallback) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
buildResponseContent(HttpResponse) - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
 
buildResponseMessage(MuleEvent, MuleEvent, Object[]) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
buildRetryPolicyExhaustedException(Exception) - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
buildScheduler() - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
buildServiceMessageProcessorChain() - Method in class org.mule.service.AbstractService
Deprecated.
 
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
 
buildUrl() - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
buildUrlFromAttributes() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
BuiltBy - Class in org.mule.module.extension.internal.capability.xml.schema.model
 
BuiltBy() - Constructor for class org.mule.module.extension.internal.capability.xml.schema.model.BuiltBy
 
BULK_MODE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.processor.AbstractUpdateProcessorBeanDefinitionParser
 
BulkExecuteMessageProcessor - Class in org.mule.module.db.internal.processor
Executes an queries in bulk mode on a database *

Accepted queries are any query with no parameters and returning an update count as result.

BulkExecuteMessageProcessor(DbConfigResolver, BulkQueryResolver, BulkQueryExecutorFactory, TransactionalAction) - Constructor for class org.mule.module.db.internal.processor.BulkExecuteMessageProcessor
 
BulkExecuteMetadataProvider - Class in org.mule.module.db.internal.metadata
Provides metadata for bulk queries
BulkExecuteMetadataProvider() - Constructor for class org.mule.module.db.internal.metadata.BulkExecuteMetadataProvider
 
BulkExecuteProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
BulkExecuteProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.BulkExecuteProcessorBeanDefinitionParser
 
BulkExecutor - Interface in org.mule.module.db.internal.domain.executor
Executes bulk queries against a database
BulkQuery - Class in org.mule.module.db.internal.domain.query
Defines a bulk of queryTemplates
BulkQuery() - Constructor for class org.mule.module.db.internal.domain.query.BulkQuery
 
BulkQueryExecutorFactory - Interface in org.mule.module.db.internal.domain.executor
Creates BulkExecutor instances
BulkQueryLogger - Interface in org.mule.module.db.internal.domain.logger
Logs a bulk query
BulkQueryResolver - Interface in org.mule.module.db.internal.resolver.query
Resolves a BulkQuery for a given MuleEvent
BulkQueryResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.query
 
BulkQueryResolverFactoryBean(String) - Constructor for class org.mule.module.db.internal.config.domain.query.BulkQueryResolverFactoryBean
 
bulkQueryText - Variable in class org.mule.module.db.internal.resolver.query.AbstractBulkQueryResolver
 
BulkUpdateExecutor - Class in org.mule.module.db.internal.domain.executor
Executes bulk queries
BulkUpdateExecutor(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.BulkUpdateExecutor
 
BulkUpdateExecutorFactory - Class in org.mule.module.db.internal.domain.executor
Creates BulkUpdateExecutor instances
BulkUpdateExecutorFactory(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.BulkUpdateExecutorFactory
 
bulkUpdateExecutorFactory - Variable in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
BulkUpdateMessageProcessorFactoryBean - Class in org.mule.module.db.internal.config.processor
Creates different AbstractBulkUpdateMessageProcessor implementations depending on whether the supplied query is parameterized or dynamic.
BulkUpdateMessageProcessorFactoryBean(DbConfigResolver, QueryResolver, BulkQueryExecutorFactory, TransactionalAction, List<QueryType>, Query) - Constructor for class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
bus - Variable in class org.mule.module.cxf.CxfInboundMessageProcessor
 
bus - Variable in class org.mule.module.cxf.support.WSDLQueryHandler
 
BUS_PROPERTY - Static variable in class org.mule.module.cxf.CxfConfiguration
 
ByParameterNameArgumentResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
An implementation of ArgumentResolver which resolves to a parameter value of name ByParameterNameArgumentResolver.parameterName
ByParameterNameArgumentResolver(String) - Constructor for class org.mule.module.extension.internal.runtime.resolver.ByParameterNameArgumentResolver
 
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
 
ByteArrayDataSource - Class in org.mule.message.ds
 
ByteArrayDataSource(byte[], String, String) - Constructor for class org.mule.message.ds.ByteArrayDataSource
 
ByteArrayHttpEntity - Class in org.mule.module.http.internal.domain
Represents a byte array entity message.
ByteArrayHttpEntity(byte[]) - Constructor for class org.mule.module.http.internal.domain.ByteArrayHttpEntity
 
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
 
BYTES - Static variable in class org.mule.module.http.api.HttpHeaders.Values

C

cache - Variable in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
cache - Variable in class org.mule.transport.jms.jndi.CachedJndiNameResolver
 
CACHE_CONTROL - Static variable in class org.mule.module.http.api.HttpHeaders.Names
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
 
cachingConnectionFactory - Variable in class org.mule.transport.jms.CachingConnectionFactoryDecorator
 
CachingConnectionFactoryDecorator - Class in org.mule.transport.jms
Decorates the JMS ConnectionFactory with a CustomCachingConnectionFactory in order to ensure JMS session instances are reused if JmsConnector.isCacheJmsSessions() is 'true' and the supplied connection factory isn't already an instance of CustomCachingConnectionFactory NOTE: Currently only Non-XA JMS 1.1 ConnectionFactory's will be decorated to provide caching.
CachingConnectionFactoryDecorator() - Constructor for class org.mule.transport.jms.CachingConnectionFactoryDecorator
 
CachingConnectionFactoryFactoryBean - Class in org.mule.transport.jms.config
Deprecated.
CachingConnectionFactoryFactoryBean() - Constructor for class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
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
 
CachingValueResolverWrapper<T> - Class in org.mule.module.extension.internal.runtime.resolver
A wrapper for an instance of ValueResolver in which the CachingValueResolverWrapper.delegate is only invoked once and the obtained value is cached.
CachingValueResolverWrapper(ValueResolver<T>) - Constructor for class org.mule.module.extension.internal.runtime.resolver.CachingValueResolverWrapper
 
calendar - Variable in class org.mule.el.datetime.AbstractInstant
 
call(Object[], ExpressionLanguageContext) - Method in interface org.mule.api.el.ExpressionLanguageFunction
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.el.function.DateTimeExpressionLanguageFuntion
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.el.function.WildcardExpressionLanguageFuntion
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.module.oauth2.internal.mel.OAuthContextExpressionLanguageFunction
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.module.xml.el.XPath3Function
 
call(Object[], ExpressionLanguageContext) - Method in class org.mule.module.xml.el.XPathFunction
Deprecated.
 
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
 
Callback<T> - Interface in org.mule.tck.listener
Callback represents an operation to be executed upon notification receive by a test listener such as ExceptionListener or FlowExecutionListener
CALLBACK_LOCATION - Static variable in interface org.mule.security.oauth.OAuthProperties
 
CallbackContinuationMessageProcessor - Class in org.mule.security.oauth.callback
This MessageProcessor acts as a wrapper of another one in order to insert it into a chain that it's not its own without being subject to its lifecycle.
CallbackContinuationMessageProcessor(MessageProcessor) - Constructor for class org.mule.security.oauth.callback.CallbackContinuationMessageProcessor
 
callbackFactory - Variable in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
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
 
camel(String) - Static method in class org.mule.module.extension.internal.util.NameUtils
Transforms a hyphenized value into a camel case one.
cancelled() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
The method will be called, when http message transferring was canceled
cancelled() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
The method will be called, when file transferring was canceled
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.
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
 
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
 
canProcessFile(String, SftpClient, long, long) - Method in class org.mule.transport.sftp.SftpReceiverRequesterUtil
Checks if the file has been changed.
canTakeFromStore() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
Capabilities - Interface in org.mule.api.devkit.capability
This interface is implemented for every org.mule.api.annotations.Module annotated class, to dynamically query what its capabilities are.
CapabilitiesResolver - Interface in org.mule.module.extension.internal.introspection
Extracts all the capabilities in a given extension and registers it on a builder
CapabilityExtractor - Interface in org.mule.module.extension
A component capable of extracting one specific capability out of a Class that composes a Capable

Because actual capabilities might be defined across several modules (or even extensions!) the actual extractors are fetched through SPI, using a ServiceRegistry.

CapabilityUtils - Class in org.mule.module.extension.internal.util
Utility class for handling capabilities
capacity - Variable in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
capacity - Variable in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
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
Deprecated.
this method was used to move the replyToDestination from the message to the event. The same must now be done explicitly inside the message receiver which creates the event.
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.
CaseInsensitiveMapWrapper<T> - Class in org.mule.util
Represents a Map from String to T where the key's case is not taken into account when looking for it, but remembered when the key set is retrieved from the map.
CaseInsensitiveMapWrapper(Class<? extends Map>, Object...) - Constructor for class org.mule.util.CaseInsensitiveMapWrapper
 
catchAll(MuleEvent) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
catchAllStrategy - Variable in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
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
Deprecated.
ChainingRouter() - Constructor for class org.mule.routing.outbound.ChainingRouter
Deprecated.
 
CHANGE_CHECK_INTERVAL_PROPERTY - Static variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
changeTimeZone(String) - Method in interface org.mule.api.el.datetime.Date
 
changeTimeZone(String) - Method in interface org.mule.api.el.datetime.Instant
 
changeTimeZone(String) - Method in interface org.mule.api.el.datetime.Time
 
changeTimeZone(String) - Method in class org.mule.el.datetime.AbstractInstant
 
changeTimeZone(String) - Method in class org.mule.el.datetime.DateTime
 
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
CHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
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
CHARSET - Static variable in class org.mule.module.http.api.HttpHeaders.Values
CharSetUtils - Class in org.mule.util
 
CharSetUtils() - Constructor for class org.mule.util.CharSetUtils
 
checkArgument(boolean, String) - Static method in class org.mule.util.Preconditions
 
checkConsumed() - Method in class org.mule.streaming.AbstractConsumer
Implement this method to actualy check for the Producer being fully consumed without worrying about it being closed or throwing any exceptions
checkConsumed() - Method in class org.mule.streaming.ListConsumer
 
checkConsumed() - Method in class org.mule.streaming.SimpleConsumer
 
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
Deprecated.
 
checkElementNameUnique(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
checkElementNameUnique(Element) - Method in class org.mule.config.spring.parsers.specific.FlowRefDefinitionParser
 
checkElementNameUnique(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
checkElementNameUnique(Element) - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
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
 
checkInstantiable(Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
checkInstantiable(Class<?>, boolean) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
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.http.OldHttpsMessageReceiver
 
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, String) - Constructor for class org.mule.config.spring.parsers.processors.CheckRequiredAttributesWhenNoChildren
 
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
checkSchemaUrl(Map<String, SchemaReference>, String, String, SchemaReference) - Method in class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
checkSchemaUrl(Map<String, SchemaReference>, String, String, SchemaReference) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
checkState() - Method in class org.mule.retry.async.FutureRetryContext
 
checkState(boolean, String) - Static method in class org.mule.util.Preconditions
 
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.
checkValidConnectionLock(DbConnection, Object) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
checkValidPayload() - Method in class org.mule.DefaultMessageCollection
 
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
This definition parser only works for maps in which each entry in the map is represented in the XML by a tag with name 'entry'.
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
 
chmod(String, int) - Method in class org.mule.transport.sftp.SftpClient
 
choice - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ComplexType
 
choice - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.ExtensionType
 
choice - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.NamedGroup
 
choice - Variable in class org.mule.module.extension.internal.capability.xml.schema.model.RestrictionType
 
ChoiceDefinition - Class in org.mule.config.dsl.routers
Deprecated.
ChoiceDefinition() - Constructor for class org.mule.config.dsl.routers.ChoiceDefinition
Deprecated.
 
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
 
CHUNKED - Static variable in class org.mule.module.http.api.HttpHeaders.Values
CLASS_PROPERTY - Static variable in class org.mule.transformer.simple.MapToBean
"className"
classFor(TypeElement, ProcessingEnvironment) - Static method in class org.mule.module.extension.internal.capability.xml.schema.AnnotationProcessorUtils
Returns the Class object that is associated to the typeElement
classLoader - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
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_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
 
ClasspathMuleCoreExtensionDiscoverer - Class in org.mule.module.launcher.coreextension
Discovers MuleCoreExtension classes that are defined in the classpath using core-extensions.properties files.
ClasspathMuleCoreExtensionDiscoverer() - Constructor for class org.mule.module.launcher.coreextension.ClasspathMuleCoreExtensionDiscoverer
 
ClassPathRegistryBootstrapDiscoverer - Class in org.mule.config.bootstrap
Looks for bootstrap properties in resources named META-INF/services/org/mule/config/registry-bootstrap.properties inside the classpath.
ClassPathRegistryBootstrapDiscoverer() - Constructor for class org.mule.config.bootstrap.ClassPathRegistryBootstrapDiscoverer
 
ClasspathScanner - Class in org.mule.util.scan
Deprecated.
ClasspathScanner(String...) - Constructor for class org.mule.util.scan.ClasspathScanner
Deprecated.
 
ClasspathScanner(ClassLoader, String...) - Constructor for class org.mule.util.scan.ClasspathScanner
Deprecated.
 
ClassReader - Class in org.mule.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.util.ClassReader
 
ClassScanner - Interface in org.mule.util.scan
Deprecated.
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
 
cleanDirectory(File) - Static method in class org.mule.util.FileUtils
Cleans a directory without deleting it.
cleanup() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
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 interface org.mule.api.store.ObjectStore
Removes all items of this store without disposing it, meaning that after performing a clear(), you should still be able perform other operations.
clear(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
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
Resets the state of this component statistics collector.
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
Deprecated.
 
clear() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
clear() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
clear() - Method in class org.mule.module.http.internal.ParameterMap
 
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() - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
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.tck.logging.TestAppender
 
clear() - Method in class org.mule.tck.util.FakeObjectStore
 
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.transport.jdbc.store.JdbcObjectStore
 
clear() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
clear() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
clear() - Method in class org.mule.util.ExceptionHolder
 
clear() - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
clear() - Method in class org.mule.util.journal.TransactionJournal
Removes all the entries from the transactional journal
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
 
clear() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
clear() - Method in class org.mule.util.queue.DefaultQueueStore
 
clear(QueueStore) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
clear() - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
clear() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
clear() - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Discards all the elements in the queue
clear(QueueInfo) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
clear(QueueStore) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
clear(QueueStore) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
clear() - Method in interface org.mule.util.queue.Queue
Discards all the elements in the queue
clear() - Method in interface org.mule.util.queue.QueueStore
 
clear() - Method in interface org.mule.util.queue.QueueStoreDelegate
Discards all the elements in the queue
clear(QueueStore) - Method in interface org.mule.util.queue.QueueTransactionContext
 
clear(QueueStore) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
clear() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
clear(QueueStore) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
clear(QueueStore) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
clear(QueueStore) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
clear() - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
clear() - Method in class org.mule.util.store.InMemoryObjectStore
 
clear() - Method in class org.mule.util.store.ManagedObjectStore
 
clear